2025.04.02 01:45:43.129403 [ 415 ] {} Context: Server was built with memory sanitizer. It will work slowly. 2025.04.02 01:45:52.129575 [ 415 ] {} KeeperLogStore: No logs exists in /var/lib/clickhouse/coordination/logs. It's Ok if it's the first run of clickhouse-keeper. 2025.04.02 01:45:52.130567 [ 415 ] {} KeeperLogStore: Removing all changelogs 2025.04.02 01:45:52.132063 [ 415 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.04.02 01:45:52.138997 [ 415 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.04.02 01:45:52.139140 [ 415 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.04.02 01:45:52.190259 [ 1023 ] {} RaftInstance: Election timeout, initiate leader election 2025.04.02 01:45:52.269528 [ 415 ] {} Access(local_directory): File /var/lib/clickhouse/access/users.list doesn't exist 2025.04.02 01:45:52.269612 [ 415 ] {} Access(local_directory): Recovering lists in directory /var/lib/clickhouse/access/ 2025.04.02 01:45:52.292978 [ 415 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.04.02 01:45:52.294320 [ 415 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.04.02 01:46:05.171686 [ 1425 ] {09378b78-d66a-45fb-9b14-bb04ad999a82} executeQuery: Code: 440. DB::Exception: LIMIT expression must be constant with numeric type. Actual arrayJoin([1, 2]). In scope SELECT * FROM system.numbers LIMIT arrayJoin([1, 2]). (INVALID_LIMIT_EXPRESSION) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42634) (comment: 01165_lost_part_empty_partition.sql) (in query: insert into rmt1(n) select * from system.numbers limit arrayJoin([1, 2]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x00000000273f45b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:861: DB::QueryAnalyzer::convertLimitOffsetExpression(std::shared_ptr&, String const&, DB::IdentifierResolveScope&) @ 0x0000000035d67855 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5649: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d27b20 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:526: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000384f4033 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:818: DB::InterpreterInsertQuery::execute() @ 0x00000000385000f6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:46:05.173617 [ 1425 ] {} TCPHandler: Code: 440. DB::Exception: LIMIT expression must be constant with numeric type. Actual arrayJoin([1, 2]). In scope SELECT * FROM system.numbers LIMIT arrayJoin([1, 2]). (INVALID_LIMIT_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x00000000273f45b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:861: DB::QueryAnalyzer::convertLimitOffsetExpression(std::shared_ptr&, String const&, DB::IdentifierResolveScope&) @ 0x0000000035d67855 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5649: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d27b20 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:526: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000384f4033 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:818: DB::InterpreterInsertQuery::execute() @ 0x00000000385000f6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:46:05.446391 [ 1372 ] {bb5736a9-f4d7-4d71-a4c7-c5f0975b42d9} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 64.00 GiB (attempt to allocate chunk of 68720001024 bytes), current RSS 0.00 B, maximum: 1.00 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42674) (comment: 02400_memory_accounting_on_error.sql) (in query: -- max_block_size to avoid randomization SELECT * FROM generateRandom('i Array(Int8)', 1, 1, 1048577) LIMIT 65536 SETTINGS max_memory_usage='1Gi', max_block_size=65505, log_queries=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000207409d0 4. ./build_docker/./src/Common/MemoryTracker.cpp:322: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002073d3c1 5. ./build_docker/./src/Common/MemoryTracker.cpp:383: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002073c803 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:58: CurrentMemoryTracker::alloc(long) @ 0x000000002061ade9 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002061596d 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000088dceb2 9. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:382: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x000000003c9f9f51 10. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:267: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x000000003c9ff45d 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:577: DB::(anonymous namespace)::GenerateSource::generate() @ 0x000000003ca0d973 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003f6e9178 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003f6e8571 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003f7213f8 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002097cef4 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002098fd26 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002098fadf 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:46:05.448746 [ 1372 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 64.00 GiB (attempt to allocate chunk of 68720001024 bytes), current RSS 0.00 B, maximum: 1.00 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000207409d0 4. ./build_docker/./src/Common/MemoryTracker.cpp:322: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002073d3c1 5. ./build_docker/./src/Common/MemoryTracker.cpp:383: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002073c803 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:58: CurrentMemoryTracker::alloc(long) @ 0x000000002061ade9 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002061596d 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000088dceb2 9. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:382: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x000000003c9f9f51 10. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:267: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x000000003c9ff45d 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:577: DB::(anonymous namespace)::GenerateSource::generate() @ 0x000000003ca0d973 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003f6e9178 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003f6e8571 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003f7213f8 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002097cef4 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002098fd26 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002098fadf 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:46:05.652481 [ 1429 ] {05cc64cf-ab31-480c-a904-af33e224106b} executeQuery: Code: 46. DB::Exception: Function with name `toDateTimeNonExistingFunction` does not exist. In scope SELECT toDateTimeNonExistingFunction(now()) RESPECT NULLS AS b. (UNKNOWN_FUNCTION) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42664) (comment: 02922_respect_nulls_parser.sql) (in query: -- Normal functions should throw in the server SELECT toDateTimeNonExistingFunction(now()) RESPECT NULLS b;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008b276d7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3305: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035da7f35 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 19. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 20. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 26. ? @ 0x00007f583d9b1ac3 27. ? @ 0x00007f583da43850 2025.04.02 01:46:05.654459 [ 1429 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `toDateTimeNonExistingFunction` does not exist. In scope SELECT toDateTimeNonExistingFunction(now()) RESPECT NULLS AS b. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008b276d7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3305: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035da7f35 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 19. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 20. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 26. ? @ 0x00007f583d9b1ac3 27. ? @ 0x00007f583da43850 2025.04.02 01:46:05.901753 [ 1422 ] {5eca7619-0e72-4e72-bea9-9e287fc9e69c} executeQuery: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(nan). (TOO_LARGE_STRING_SIZE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42676) (comment: 01054_random_printable_ascii_ubsan.sh) (in query: SELECT randomPrintableASCII(nan);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b334c20 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:46:05.904041 [ 1422 ] {} TCPHandler: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(nan). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b334c20 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:46:06.072374 [ 1424 ] {65c49dcb-fdac-4efe-a79c-4a8c3aa654ed} executeQuery: Code: 69. DB::Exception: Scale argument for rounding function is too large: In scope SELECT ceil(29375422, -54212). (ARGUMENT_OUT_OF_BOUND) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42624) (comment: 00161_rounding_functions.sql) (in query: SELECT ceil(29375422, -54212) --{serverError ARGUMENT_OUT_OF_BOUND} ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. COW::immutable_ptr DB::Dispatcher::apply(DB::IColumn const*, DB::IColumn const*) @ 0x000000000a710073 5. bool DB::FunctionRounding::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000000a69dd5c 6. DB::FunctionRounding::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a69665d 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 29. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 30. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 2025.04.02 01:46:06.073562 [ 1424 ] {} TCPHandler: Code: 69. DB::Exception: Scale argument for rounding function is too large: In scope SELECT ceil(29375422, -54212). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. COW::immutable_ptr DB::Dispatcher::apply(DB::IColumn const*, DB::IColumn const*) @ 0x000000000a710073 5. bool DB::FunctionRounding::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000000a69dd5c 6. DB::FunctionRounding::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a69665d 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 29. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 30. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 2025.04.02 01:46:06.282691 [ 1429 ] {60ef18f5-b3e1-43b5-89a8-befceb0a028b} executeQuery: Code: 62. DB::Exception: Function with name `toDateTime` cannot use RESPECT NULLS. (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42664) (comment: 02922_respect_nulls_parser.sql) (in query: SELECT toDateTime(now()) RESPECT NULLS b;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000002748ca2d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2637: DB::(anonymous namespace)::checkFunctionNodeHasEmptyNullsAction(DB::FunctionNode const&) @ 0x0000000035dd2719 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3277: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d971c5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 20. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 21. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 27. ? @ 0x00007f583d9b1ac3 28. ? @ 0x00007f583da43850 2025.04.02 01:46:06.284045 [ 1429 ] {} TCPHandler: Code: 62. DB::Exception: Function with name `toDateTime` cannot use RESPECT NULLS. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000002748ca2d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2637: DB::(anonymous namespace)::checkFunctionNodeHasEmptyNullsAction(DB::FunctionNode const&) @ 0x0000000035dd2719 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3277: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d971c5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 20. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 21. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 27. ? @ 0x00007f583d9b1ac3 28. ? @ 0x00007f583da43850 2025.04.02 01:46:06.671695 [ 1410 ] {fc83ffa7-cf19-42d9-8ee2-68ba61d9f5a8} executeQuery: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(inf). (TOO_LARGE_STRING_SIZE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42724) (comment: 01054_random_printable_ascii_ubsan.sh) (in query: SELECT randomPrintableASCII(inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b334c20 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:46:06.673528 [ 1410 ] {} TCPHandler: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(inf). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b334c20 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:46:06.849296 [ 1429 ] {3dbfd0be-701a-4bbc-847b-f7805398a49f} executeQuery: Code: 62. DB::Exception: Function with name `in` cannot use RESPECT NULLS. (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42664) (comment: 02922_respect_nulls_parser.sql) (in query: SELECT count() from numbers(10) where in(number, (0)) RESPECT NULLS;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000002748ca2d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2637: DB::(anonymous namespace)::checkFunctionNodeHasEmptyNullsAction(DB::FunctionNode const&) @ 0x0000000035dd2719 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2908: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8de0b 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5588: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d2578b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 18. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 19. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 25. ? @ 0x00007f583d9b1ac3 26. ? @ 0x00007f583da43850 2025.04.02 01:46:06.850908 [ 1429 ] {} TCPHandler: Code: 62. DB::Exception: Function with name `in` cannot use RESPECT NULLS. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000002748ca2d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2637: DB::(anonymous namespace)::checkFunctionNodeHasEmptyNullsAction(DB::FunctionNode const&) @ 0x0000000035dd2719 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2908: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8de0b 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5588: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d2578b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 18. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 19. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 25. ? @ 0x00007f583d9b1ac3 26. ? @ 0x00007f583da43850 2025.04.02 01:46:07.204438 [ 1070 ] {} test_nqm5w1bi.rmt2 (57417230-47df-49c6-97ac-90fcbe90443e): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://421e3960cfe6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_nqm5w1bi%2Frmt%2Freplicas%2F1&part=20250401_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 137 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.12.2.20221.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x00000000210698f9 4. ./build_docker/./src/IO/HTTPCommon.cpp:92: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000021069277 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x00000000274803e3 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000274808b5 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000274825a9 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000027489e47 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002747af85 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000027485e92 11. DB::ReadBuffer::next() @ 0x0000000008c442cf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002747f42d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000027463a30 14. ./src/IO/ReadWriteBufferFromHTTP.h:247: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003da40600 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5183: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003d14214a 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003ce95810 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2504: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003ce6bbb0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2340: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000003ce2cb9e 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3866: bool std::__function::__policy_invoker&)>::__call_impl)::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x000000003d13a7f0 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003e9069ec 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3862: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003cf1242b 22. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3925: bool std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003d13c799 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003d1b40f7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:308: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003ddd3300 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:353: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003ddd4f0c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003dde539f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002097cef4 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002098fd26 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002098fadf 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:46:07.432552 [ 1427 ] {28023004-2472-49ef-bd27-8c2ce3e6f26e} executeQuery: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(-inf). (TOO_LARGE_STRING_SIZE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42750) (comment: 01054_random_printable_ascii_ubsan.sh) (in query: SELECT randomPrintableASCII(-inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b334c20 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:46:07.435149 [ 1427 ] {} TCPHandler: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(-inf). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b334c20 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:46:07.474787 [ 1429 ] {58aaf259-b3a2-4e52-8b38-32e514ded2ae} executeQuery: Code: 62. DB::Exception: Function with name `if` cannot use RESPECT NULLS. (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42664) (comment: 02922_respect_nulls_parser.sql) (in query: SELECT if(number > 0, number, 0) respect nulls from numbers(0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000002748ca2d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2637: DB::(anonymous namespace)::checkFunctionNodeHasEmptyNullsAction(DB::FunctionNode const&) @ 0x0000000035dd2719 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2824: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8bd84 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 20. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 21. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 27. ? @ 0x00007f583d9b1ac3 28. ? @ 0x00007f583da43850 2025.04.02 01:46:07.476254 [ 1429 ] {} TCPHandler: Code: 62. DB::Exception: Function with name `if` cannot use RESPECT NULLS. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000002748ca2d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2637: DB::(anonymous namespace)::checkFunctionNodeHasEmptyNullsAction(DB::FunctionNode const&) @ 0x0000000035dd2719 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2824: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8bd84 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 20. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 21. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 27. ? @ 0x00007f583d9b1ac3 28. ? @ 0x00007f583da43850 2025.04.02 01:46:07.495463 [ 759 ] {} test_nqm5w1bi.rmt2 (ReplicatedMergeTreePartCheckThread): No replica has part covering 20250401_0_0_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.04.02 01:46:07.521341 [ 759 ] {} test_nqm5w1bi.rmt2 (ReplicatedMergeTreePartCheckThread): Part 20250401_0_0_0 is lost forever. 2025.04.02 01:46:07.672663 [ 1423 ] {ee44156d-c294-4c67-8723-9aec7b20ee75} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42714) (comment: 00417_kill_query.sh) (in query: SELECT sleep(1) FROM system.numbers LIMIT 300), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:46:07.760903 [ 1423 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:46:07.867630 [ 1046 ] {487aee97-caf1-47a4-b8d6-4929c72f903d::all_1_1_0_7} MutatePlainMergeTreeTask: Code: 190. DB::Exception: Elements '[100, 200]' and '['a', 'b', 'c']' of Nested data structure (Array columns) have different array sizes (2 and 3 respectively) on row 0: while executing 'FUNCTION validateNestedArraySizes(equals(id, 0) : 13, [100, 200] :: 5, ['a', 'b', 'c'] :: 6, [10, 20, 30] :: 7) -> validateNestedArraySizes(equals(id, 0), [100, 200], ['a', 'b', 'c'], [10, 20, 30]) UInt8 : 4'. (SIZES_OF_ARRAYS_DONT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:46:08.103481 [ 1429 ] {d1d46e3a-7868-4c44-95ff-3f8bf6f3a23d} executeQuery: Code: 62. DB::Exception: Function with name `lambda` cannot use RESPECT NULLS. (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42664) (comment: 02922_respect_nulls_parser.sql) (in query: WITH (x -> x + 1) AS lambda SELECT lambda(number) RESPECT NULLS FROM numbers(10) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000002748ca2d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2637: DB::(anonymous namespace)::checkFunctionNodeHasEmptyNullsAction(DB::FunctionNode const&) @ 0x0000000035dd2719 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3123: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d95c43 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 20. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 21. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 27. ? @ 0x00007f583d9b1ac3 28. ? @ 0x00007f583da43850 2025.04.02 01:46:08.104818 [ 1429 ] {} TCPHandler: Code: 62. DB::Exception: Function with name `lambda` cannot use RESPECT NULLS. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000002748ca2d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2637: DB::(anonymous namespace)::checkFunctionNodeHasEmptyNullsAction(DB::FunctionNode const&) @ 0x0000000035dd2719 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3123: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d95c43 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 20. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 21. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 27. ? @ 0x00007f583d9b1ac3 28. ? @ 0x00007f583da43850 2025.04.02 01:46:08.174895 [ 422 ] {9da71c46-f2d4-4962-a4da-653dd2a4fe93} executeQuery: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(1e300). (TOO_LARGE_STRING_SIZE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42790) (comment: 01054_random_printable_ascii_ubsan.sh) (in query: SELECT randomPrintableASCII(1e300);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b334c20 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:46:08.176690 [ 422 ] {} TCPHandler: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(1e300). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b334c20 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:46:08.611396 [ 1046 ] {487aee97-caf1-47a4-b8d6-4929c72f903d::all_1_1_0_7} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 190. DB::Exception: Elements '[100, 200]' and '['a', 'b', 'c']' of Nested data structure (Array columns) have different array sizes (2 and 3 respectively) on row 0: while executing 'FUNCTION validateNestedArraySizes(equals(id, 0) : 13, [100, 200] :: 5, ['a', 'b', 'c'] :: 6, [10, 20, 30] :: 7) -> validateNestedArraySizes(equals(id, 0), [100, 200], ['a', 'b', 'c'], [10, 20, 30]) UInt8 : 4'. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, unsigned long&, unsigned long&, unsigned long&) @ 0x000000001c11f187 4. DB::FunctionValidateNestedArraySizes::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c11e2d9 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x00000000400e3001 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027d13b04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003f6df04b 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762e32 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 18. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1222: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000003e665e75 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1136: DB::PartMergerWriter::execute() @ 0x000000003e6d3c93 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1712: DB::MutateSomePartColumnsTask::executeStep() @ 0x000000003e6d6225 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2002: DB::MutateTask::execute() @ 0x000000003e67277f 22. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:99: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003eb9d044 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:308: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003dddcfa0 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:353: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003ddded21 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003dde677f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002097cef4 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002098fd26 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002098fadf 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 31. ? @ 0x00007f583d9b1ac3 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:46:08.612077 [ 1046 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {487aee97-caf1-47a4-b8d6-4929c72f903d::all_1_1_0_7}: Code: 190. DB::Exception: Elements '[100, 200]' and '['a', 'b', 'c']' of Nested data structure (Array columns) have different array sizes (2 and 3 respectively) on row 0: while executing 'FUNCTION validateNestedArraySizes(equals(id, 0) : 13, [100, 200] :: 5, ['a', 'b', 'c'] :: 6, [10, 20, 30] :: 7) -> validateNestedArraySizes(equals(id, 0), [100, 200], ['a', 'b', 'c'], [10, 20, 30]) UInt8 : 4'. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, unsigned long&, unsigned long&, unsigned long&) @ 0x000000001c11f187 4. DB::FunctionValidateNestedArraySizes::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c11e2d9 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x00000000400e3001 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027d13b04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003f6df04b 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762e32 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 18. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1222: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000003e665e75 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1136: DB::PartMergerWriter::execute() @ 0x000000003e6d3c93 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1712: DB::MutateSomePartColumnsTask::executeStep() @ 0x000000003e6d6225 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2002: DB::MutateTask::execute() @ 0x000000003e67277f 22. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:99: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003eb9d044 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:308: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003dddcfa0 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:353: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003ddded21 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003dde677f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002097cef4 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002098fd26 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002098fadf 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 31. ? @ 0x00007f583d9b1ac3 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:46:08.669869 [ 1429 ] {c0e05de2-96a5-4d64-88d1-dc4b585da6cc} executeQuery: Code: 62. DB::Exception: Function with name `indexHint` cannot use RESPECT NULLS. (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42664) (comment: 02922_respect_nulls_parser.sql) (in query: SELECT * from system.one WHERE indexHint(dummy = 1) RESPECT NULLS;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000002748ca2d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2637: DB::(anonymous namespace)::checkFunctionNodeHasEmptyNullsAction(DB::FunctionNode const&) @ 0x0000000035dd2719 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3277: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d971c5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5588: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d2578b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 18. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 19. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 25. ? @ 0x00007f583d9b1ac3 26. ? @ 0x00007f583da43850 2025.04.02 01:46:08.675860 [ 1429 ] {} TCPHandler: Code: 62. DB::Exception: Function with name `indexHint` cannot use RESPECT NULLS. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000002748ca2d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2637: DB::(anonymous namespace)::checkFunctionNodeHasEmptyNullsAction(DB::FunctionNode const&) @ 0x0000000035dd2719 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3277: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d971c5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5588: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d2578b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 18. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 19. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 25. ? @ 0x00007f583d9b1ac3 26. ? @ 0x00007f583da43850 2025.04.02 01:46:08.692811 [ 1429 ] {1cb50d31-4dd5-40de-b757-834ca9affa41} executeQuery: Code: 62. DB::Exception: Function with name `arrayJoin` cannot use IGNORE NULLS. (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42664) (comment: 02922_respect_nulls_parser.sql) (in query: SELECT arrayJoin([[3,4,5], [6,7], [2], [1,1]]) IGNORE NULLS;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000002748ca2d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2637: DB::(anonymous namespace)::checkFunctionNodeHasEmptyNullsAction(DB::FunctionNode const&) @ 0x0000000035dd2719 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3277: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d971c5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 20. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 21. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 27. ? @ 0x00007f583d9b1ac3 28. ? @ 0x00007f583da43850 2025.04.02 01:46:08.694215 [ 1429 ] {} TCPHandler: Code: 62. DB::Exception: Function with name `arrayJoin` cannot use IGNORE NULLS. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000002748ca2d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2637: DB::(anonymous namespace)::checkFunctionNodeHasEmptyNullsAction(DB::FunctionNode const&) @ 0x0000000035dd2719 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3277: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d971c5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 20. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 21. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 27. ? @ 0x00007f583d9b1ac3 28. ? @ 0x00007f583da43850 2025.04.02 01:46:08.788552 [ 1422 ] {42f17e5f-c9bc-4e30-8fa3-bac10f2eb707} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_7.txt' with part 'all_1_1_0_6' reason: 'Code: 190. DB::Exception: Elements '[100, 200]' and '['a', 'b', 'c']' of Nested data structure (Array columns) have different array sizes (2 and 3 respectively) on row 0: while executing 'FUNCTION validateNestedArraySizes(equals(id, 0) : 13, [100, 200] :: 5, ['a', 'b', 'c'] :: 6, [10, 20, 30] :: 7) -> validateNestedArraySizes(equals(id, 0), [100, 200], ['a', 'b', 'c'], [10, 20, 30]) UInt8 : 4'. (SIZES_OF_ARRAYS_DONT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:381: StackTrace::tryCapture() @ 0x000000002077fc7b 1. ./src/Common/StackTrace.h:48: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000003e3edb4e 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:662: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003eac5b79 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:632: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003eac93e6 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:239: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775cb6f 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 . (UNFINISHED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42740) (comment: 01788_update_nested_type_subcolumn_check.sql) (in query: alter table test_wide_nested update `info.id` = [100,200], `info.age` = [10,20,30], `info.name` = ['a','b','c'] where id = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x000000003e3ede87 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000003e3edc0f 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:662: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003eac5b79 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:632: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003eac93e6 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:239: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775cb6f 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:46:08.790432 [ 1422 ] {} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_7.txt' with part 'all_1_1_0_6' reason: 'Code: 190. DB::Exception: Elements '[100, 200]' and '['a', 'b', 'c']' of Nested data structure (Array columns) have different array sizes (2 and 3 respectively) on row 0: while executing 'FUNCTION validateNestedArraySizes(equals(id, 0) : 13, [100, 200] :: 5, ['a', 'b', 'c'] :: 6, [10, 20, 30] :: 7) -> validateNestedArraySizes(equals(id, 0), [100, 200], ['a', 'b', 'c'], [10, 20, 30]) UInt8 : 4'. (SIZES_OF_ARRAYS_DONT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:381: StackTrace::tryCapture() @ 0x000000002077fc7b 1. ./src/Common/StackTrace.h:48: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000003e3edb4e 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:662: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003eac5b79 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:632: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003eac93e6 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:239: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775cb6f 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 . (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x000000003e3ede87 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000003e3edc0f 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:662: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003eac5b79 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:632: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003eac93e6 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:239: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775cb6f 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:46:08.925961 [ 1427 ] {3613d164-b7f3-4c72-8185-1f19b0cc9153} executeQuery: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(-123.456). (TOO_LARGE_STRING_SIZE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42838) (comment: 01054_random_printable_ascii_ubsan.sh) (in query: SELECT randomPrintableASCII(-123.456);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b334c20 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:46:08.927646 [ 1427 ] {} TCPHandler: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(-123.456). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b334c20 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:46:09.286225 [ 1061 ] {3386a848-abec-42d3-85e8-6f85028ac8c6::all_1_1_0_3} MutatePlainMergeTreeTask: Code: 190. DB::Exception: Elements '[10, 20, 30]' and 'info.age' of Nested data structure (Array columns) have different array sizes (3 and 2 respectively) on row 1: while executing 'FUNCTION validateNestedArraySizes(equals(id, 1) : 9, [10, 20, 30] :: 4, info.age : 2) -> validateNestedArraySizes(equals(id, 1), [10, 20, 30], info.age) UInt8 : 3'. (SIZES_OF_ARRAYS_DONT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:46:09.286646 [ 1061 ] {3386a848-abec-42d3-85e8-6f85028ac8c6::all_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 190. DB::Exception: Elements '[10, 20, 30]' and 'info.age' of Nested data structure (Array columns) have different array sizes (3 and 2 respectively) on row 1: while executing 'FUNCTION validateNestedArraySizes(equals(id, 1) : 9, [10, 20, 30] :: 4, info.age : 2) -> validateNestedArraySizes(equals(id, 1), [10, 20, 30], info.age) UInt8 : 3'. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, unsigned long&, unsigned long&, unsigned long&) @ 0x000000001c11f187 4. DB::FunctionValidateNestedArraySizes::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c11e2d9 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x00000000400e3001 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027d13b04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003f6df04b 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762e32 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 18. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1222: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000003e665e75 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1136: DB::PartMergerWriter::execute() @ 0x000000003e6d3c93 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1712: DB::MutateSomePartColumnsTask::executeStep() @ 0x000000003e6d6225 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2002: DB::MutateTask::execute() @ 0x000000003e67277f 22. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:99: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003eb9d044 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:308: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003dddcfa0 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:353: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003ddded21 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003dde677f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002097cef4 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002098fd26 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002098fadf 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 31. ? @ 0x00007f583d9b1ac3 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:46:09.287013 [ 1061 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3386a848-abec-42d3-85e8-6f85028ac8c6::all_1_1_0_3}: Code: 190. DB::Exception: Elements '[10, 20, 30]' and 'info.age' of Nested data structure (Array columns) have different array sizes (3 and 2 respectively) on row 1: while executing 'FUNCTION validateNestedArraySizes(equals(id, 1) : 9, [10, 20, 30] :: 4, info.age : 2) -> validateNestedArraySizes(equals(id, 1), [10, 20, 30], info.age) UInt8 : 3'. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, unsigned long&, unsigned long&, unsigned long&) @ 0x000000001c11f187 4. DB::FunctionValidateNestedArraySizes::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c11e2d9 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x00000000400e3001 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027d13b04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003f6df04b 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762e32 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 18. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1222: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000003e665e75 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1136: DB::PartMergerWriter::execute() @ 0x000000003e6d3c93 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1712: DB::MutateSomePartColumnsTask::executeStep() @ 0x000000003e6d6225 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2002: DB::MutateTask::execute() @ 0x000000003e67277f 22. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:99: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003eb9d044 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:308: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003dddcfa0 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:353: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003ddded21 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003dde677f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002097cef4 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002098fd26 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002098fadf 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 31. ? @ 0x00007f583d9b1ac3 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:46:09.287794 [ 1422 ] {28124f8c-e0c5-4a65-8bb8-fdeedd1ad9a4} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part 'all_1_1_0_2' reason: 'Code: 190. DB::Exception: Elements '[10, 20, 30]' and 'info.age' of Nested data structure (Array columns) have different array sizes (3 and 2 respectively) on row 1: while executing 'FUNCTION validateNestedArraySizes(equals(id, 1) : 9, [10, 20, 30] :: 4, info.age : 2) -> validateNestedArraySizes(equals(id, 1), [10, 20, 30], info.age) UInt8 : 3'. (SIZES_OF_ARRAYS_DONT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:381: StackTrace::tryCapture() @ 0x000000002077fc7b 1. ./src/Common/StackTrace.h:48: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000003e3edb4e 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:662: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003eac5b79 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:632: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003eac93e6 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:239: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775cb6f 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 . (UNFINISHED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42740) (comment: 01788_update_nested_type_subcolumn_check.sql) (in query: alter table test_wide_nested update `info.id` = [100,200,300], `info.age` = [10,20,30] where id = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x000000003e3ede87 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000003e3edc0f 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:662: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003eac5b79 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:632: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003eac93e6 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:239: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775cb6f 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:46:09.289711 [ 1422 ] {} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part 'all_1_1_0_2' reason: 'Code: 190. DB::Exception: Elements '[10, 20, 30]' and 'info.age' of Nested data structure (Array columns) have different array sizes (3 and 2 respectively) on row 1: while executing 'FUNCTION validateNestedArraySizes(equals(id, 1) : 9, [10, 20, 30] :: 4, info.age : 2) -> validateNestedArraySizes(equals(id, 1), [10, 20, 30], info.age) UInt8 : 3'. (SIZES_OF_ARRAYS_DONT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:381: StackTrace::tryCapture() @ 0x000000002077fc7b 1. ./src/Common/StackTrace.h:48: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000003e3edb4e 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:662: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003eac5b79 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:632: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003eac93e6 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:239: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775cb6f 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 . (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x000000003e3ede87 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000003e3edc0f 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:662: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003eac5b79 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:632: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003eac93e6 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:239: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775cb6f 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:46:09.346823 [ 1429 ] {db127920-6b01-4aae-9dc3-6cf85a2c76fd} executeQuery: Code: 62. DB::Exception: Function with name `grouping` cannot use RESPECT NULLS. (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42664) (comment: 02922_respect_nulls_parser.sql) (in query: SELECT number, grouping(number % 2, number) RESPECT NULLS AS gr FROM numbers(10) GROUP BY GROUPING SETS ((number), (number % 2)) SETTINGS force_grouping_standard_compatibility = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000002748ca2d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2637: DB::(anonymous namespace)::checkFunctionNodeHasEmptyNullsAction(DB::FunctionNode const&) @ 0x0000000035dd2719 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3210: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035da01fe 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 20. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 21. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 27. ? @ 0x00007f583d9b1ac3 28. ? @ 0x00007f583da43850 2025.04.02 01:46:09.348393 [ 1429 ] {} TCPHandler: Code: 62. DB::Exception: Function with name `grouping` cannot use RESPECT NULLS. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000002748ca2d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2637: DB::(anonymous namespace)::checkFunctionNodeHasEmptyNullsAction(DB::FunctionNode const&) @ 0x0000000035dd2719 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3210: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035da01fe 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 20. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 21. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 27. ? @ 0x00007f583d9b1ac3 28. ? @ 0x00007f583da43850 2025.04.02 01:46:09.446382 [ 423 ] {73ec0d7e-1cc5-4185-b7c0-f8a7a9892995} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42816) (comment: 00417_kill_query.sh) (in query: SELECT sleep(1) FROM system.numbers LIMIT 301), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:46:09.448598 [ 423 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:46:09.696405 [ 1372 ] {9fd944fc-3e0e-4b45-812e-bb333cf96287} executeQuery: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(-1). (TOO_LARGE_STRING_SIZE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:53342) (comment: 01054_random_printable_ascii_ubsan.sh) (in query: SELECT randomPrintableASCII(-1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b334c20 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:46:09.698180 [ 1372 ] {} TCPHandler: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(-1). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b334c20 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:46:09.862470 [ 1080 ] {} test_nqm5w1bi.rmt2 (099af253-71df-4ce9-80a8-0e4e5c252eba): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://421e3960cfe6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_nqm5w1bi%2Frmt%2Freplicas%2F1&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 137 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.12.2.20221.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x00000000210698f9 4. ./build_docker/./src/IO/HTTPCommon.cpp:92: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000021069277 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x00000000274803e3 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000274808b5 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000274825a9 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000027489e47 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002747af85 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000027485e92 11. DB::ReadBuffer::next() @ 0x0000000008c442cf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002747f42d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000027463a30 14. ./src/IO/ReadWriteBufferFromHTTP.h:247: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003da40600 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5183: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003d14214a 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003ce95810 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2504: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003ce6bbb0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2340: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000003ce2cb9e 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3866: bool std::__function::__policy_invoker&)>::__call_impl)::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x000000003d13a7f0 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003e9069ec 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3862: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003cf1242b 22. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3925: bool std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003d13c799 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003d1b40f7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:308: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003ddd3300 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:353: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003ddd4f0c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003dde539f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002097cef4 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002098fd26 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002098fadf 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:46:09.899473 [ 952 ] {} test_nqm5w1bi.rmt2 (ReplicatedMergeTreePartCheckThread): No replica has part covering all_0_0_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.04.02 01:46:09.911907 [ 952 ] {} test_nqm5w1bi.rmt2 (ReplicatedMergeTreePartCheckThread): Part all_0_0_0 is lost forever. 2025.04.02 01:46:11.844228 [ 1074 ] {} test_nqm5w1bi.rmt2 (14c505d6-8ed8-4684-9eaa-d2268d21eaec): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://421e3960cfe6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_nqm5w1bi%2Frmt%2Freplicas%2F1&part=176-1950939435-20250401-1743543971_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 137 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.12.2.20221.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x00000000210698f9 4. ./build_docker/./src/IO/HTTPCommon.cpp:92: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000021069277 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x00000000274803e3 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000274808b5 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000274825a9 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000027489e47 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002747af85 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000027485e92 11. DB::ReadBuffer::next() @ 0x0000000008c442cf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002747f42d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000027463a30 14. ./src/IO/ReadWriteBufferFromHTTP.h:247: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003da40600 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5183: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003d14214a 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003ce95810 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2504: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003ce6bbb0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2340: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000003ce2cb9e 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3866: bool std::__function::__policy_invoker&)>::__call_impl)::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x000000003d13a7f0 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003e9069ec 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3862: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003cf1242b 22. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3925: bool std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003d13c799 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003d1b40f7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:308: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003ddd3300 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:353: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003ddd4f0c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003dde539f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002097cef4 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002098fd26 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002098fadf 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:46:11.896609 [ 1079 ] {} test_nqm5w1bi.rmt2 (14c505d6-8ed8-4684-9eaa-d2268d21eaec): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://421e3960cfe6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_nqm5w1bi%2Frmt%2Freplicas%2F1&part=176-1950939435-20250401-1743543971_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 137 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.12.2.20221.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x00000000210698f9 4. ./build_docker/./src/IO/HTTPCommon.cpp:92: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000021069277 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x00000000274803e3 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000274808b5 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000274825a9 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000027489e47 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002747af85 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000027485e92 11. DB::ReadBuffer::next() @ 0x0000000008c442cf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002747f42d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000027463a30 14. ./src/IO/ReadWriteBufferFromHTTP.h:247: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003da40600 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5183: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003d14214a 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003ce95810 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2504: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003ce6bbb0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2340: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000003ce2cb9e 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3866: bool std::__function::__policy_invoker&)>::__call_impl)::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x000000003d13a7f0 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003e9069ec 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3862: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003cf1242b 22. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3925: bool std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003d13c799 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003d1b40f7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:308: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003ddd3300 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:353: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003ddd4f0c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003dde539f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002097cef4 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002098fd26 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002098fadf 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:46:11.897742 [ 1076 ] {} test_nqm5w1bi.rmt2 (14c505d6-8ed8-4684-9eaa-d2268d21eaec): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://421e3960cfe6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_nqm5w1bi%2Frmt%2Freplicas%2F1&part=83--522871241-20250401-1743543971_1_1_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 137 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.12.2.20221.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x00000000210698f9 4. ./build_docker/./src/IO/HTTPCommon.cpp:92: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000021069277 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x00000000274803e3 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000274808b5 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000274825a9 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000027489e47 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002747af85 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000027485e92 11. DB::ReadBuffer::next() @ 0x0000000008c442cf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002747f42d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000027463a30 14. ./src/IO/ReadWriteBufferFromHTTP.h:247: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003da40600 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5183: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003d14214a 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003ce95810 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2504: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003ce6bbb0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2340: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000003ce2cb9e 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3866: bool std::__function::__policy_invoker&)>::__call_impl)::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x000000003d13a7f0 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003e9069ec 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3862: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003cf1242b 22. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3925: bool std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003d13c799 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003d1b40f7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:308: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003ddd3300 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:353: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003ddd4f0c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003dde539f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002097cef4 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002098fd26 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002098fadf 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:46:11.949801 [ 1071 ] {} test_nqm5w1bi.rmt2 (14c505d6-8ed8-4684-9eaa-d2268d21eaec): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://421e3960cfe6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_nqm5w1bi%2Frmt%2Freplicas%2F1&part=87--251156434-20250401-1743543971_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 137 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.12.2.20221.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x00000000210698f9 4. ./build_docker/./src/IO/HTTPCommon.cpp:92: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000021069277 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x00000000274803e3 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000274808b5 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000274825a9 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000027489e47 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002747af85 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000027485e92 11. DB::ReadBuffer::next() @ 0x0000000008c442cf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002747f42d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000027463a30 14. ./src/IO/ReadWriteBufferFromHTTP.h:247: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003da40600 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5183: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003d14214a 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003ce95810 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2504: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003ce6bbb0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2340: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000003ce2cb9e 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3866: bool std::__function::__policy_invoker&)>::__call_impl)::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x000000003d13a7f0 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003e9069ec 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3862: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003cf1242b 22. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3925: bool std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003d13c799 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003d1b40f7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:308: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003ddd3300 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:353: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003ddd4f0c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003dde539f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002097cef4 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002098fd26 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002098fadf 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:46:11.949911 [ 1084 ] {} test_nqm5w1bi.rmt2 (14c505d6-8ed8-4684-9eaa-d2268d21eaec): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://421e3960cfe6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_nqm5w1bi%2Frmt%2Freplicas%2F1&part=83--522871241-20250401-1743543971_1_1_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 137 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.12.2.20221.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x00000000210698f9 4. ./build_docker/./src/IO/HTTPCommon.cpp:92: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000021069277 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x00000000274803e3 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000274808b5 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000274825a9 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000027489e47 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002747af85 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000027485e92 11. DB::ReadBuffer::next() @ 0x0000000008c442cf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002747f42d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000027463a30 14. ./src/IO/ReadWriteBufferFromHTTP.h:247: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003da40600 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5183: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003d14214a 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003ce95810 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2504: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003ce6bbb0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2340: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000003ce2cb9e 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3866: bool std::__function::__policy_invoker&)>::__call_impl)::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x000000003d13a7f0 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003e9069ec 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3862: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003cf1242b 22. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3925: bool std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003d13c799 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003d1b40f7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:308: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003ddd3300 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:353: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003ddd4f0c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003dde539f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002097cef4 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002098fd26 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002098fadf 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:46:11.950943 [ 1085 ] {} test_nqm5w1bi.rmt2 (14c505d6-8ed8-4684-9eaa-d2268d21eaec): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://421e3960cfe6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_nqm5w1bi%2Frmt%2Freplicas%2F1&part=176-1950939435-20250401-1743543971_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 137 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.12.2.20221.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x00000000210698f9 4. ./build_docker/./src/IO/HTTPCommon.cpp:92: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000021069277 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x00000000274803e3 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000274808b5 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000274825a9 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000027489e47 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002747af85 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000027485e92 11. DB::ReadBuffer::next() @ 0x0000000008c442cf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002747f42d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000027463a30 14. ./src/IO/ReadWriteBufferFromHTTP.h:247: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003da40600 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5183: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003d14214a 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003ce95810 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2504: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003ce6bbb0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2340: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000003ce2cb9e 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3866: bool std::__function::__policy_invoker&)>::__call_impl)::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x000000003d13a7f0 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003e9069ec 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3862: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003cf1242b 22. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3925: bool std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003d13c799 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003d1b40f7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:308: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003ddd3300 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:353: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003ddd4f0c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003dde539f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002097cef4 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002098fd26 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002098fadf 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:46:11.988900 [ 590 ] {} test_nqm5w1bi.rmt2 (ReplicatedMergeTreePartCheckThread): No replica has part covering 176-1950939435-20250401-1743543971_0_0_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.04.02 01:46:12.014533 [ 590 ] {} test_nqm5w1bi.rmt2 (ReplicatedMergeTreePartCheckThread): Part 176-1950939435-20250401-1743543971_0_0_0 is lost forever. 2025.04.02 01:46:12.017187 [ 590 ] {} test_nqm5w1bi.rmt2 (ReplicatedMergeTreePartCheckThread): No replica has part covering 87--251156434-20250401-1743543971_0_0_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.04.02 01:46:12.035922 [ 590 ] {} test_nqm5w1bi.rmt2 (ReplicatedMergeTreePartCheckThread): Part 87--251156434-20250401-1743543971_0_0_0 is lost forever. 2025.04.02 01:46:12.037427 [ 590 ] {} test_nqm5w1bi.rmt2 (ReplicatedMergeTreePartCheckThread): No replica has part covering 83--522871241-20250401-1743543971_1_1_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.04.02 01:46:12.059270 [ 590 ] {} test_nqm5w1bi.rmt2 (ReplicatedMergeTreePartCheckThread): Part 83--522871241-20250401-1743543971_1_1_0 is lost forever. 2025.04.02 01:46:12.299989 [ 1432 ] {16cdc573-331b-46eb-b797-0309cdd9960d} executeQuery: Code: 264. DB::Exception: JOIN keys should match to the Join engine keys [k]. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:53388) (comment: 00118_storage_join.sql) (in query: SELECT k, js1.s, t2.s FROM (SELECT number AS k, number AS s FROM system.numbers LIMIT 10) js1 ANY LEFT JOIN t2 ON js1.k == t2.k OR js1.s == t2.k ORDER BY k;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x000000003ca57c0a 4. ./build_docker/./src/Storages/StorageJoin.cpp:254: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x000000003ca50570 5. ./build_docker/./src/Planner/PlannerJoins.cpp:905: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x000000003873d11e 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1690: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000386e5233 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000386b9598 8. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000003865cf3b 9. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 20. ? @ 0x00007f583d9b1ac3 21. ? @ 0x00007f583da43850 2025.04.02 01:46:12.301666 [ 1432 ] {} TCPHandler: Code: 264. DB::Exception: JOIN keys should match to the Join engine keys [k]. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x000000003ca57c0a 4. ./build_docker/./src/Storages/StorageJoin.cpp:254: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x000000003ca50570 5. ./build_docker/./src/Planner/PlannerJoins.cpp:905: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x000000003873d11e 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1690: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000386e5233 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000386b9598 8. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000003865cf3b 9. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 20. ? @ 0x00007f583d9b1ac3 21. ? @ 0x00007f583da43850 2025.04.02 01:46:14.914517 [ 1429 ] {5df7ad47-dc32-4f34-ae4e-38420d1fce3b} executeQuery: Code: 442. DB::Exception: Temporary tables cannot be inside a database. You should not specify a database for a temporary table. (BAD_DATABASE_FOR_TEMPORARY_TABLE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:53602) (comment: 00841_temporary_table_database.sql) (in query: CREATE TEMPORARY TABLE test.t2_00841 (x UInt8);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1522: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cd689 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:46:14.916051 [ 1429 ] {} TCPHandler: Code: 442. DB::Exception: Temporary tables cannot be inside a database. You should not specify a database for a temporary table. (BAD_DATABASE_FOR_TEMPORARY_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1522: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cd689 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:46:19.715626 [ 890 ] {} test_zoukkc2i.rmt (76c20f42-4366-4e32-b955-2f18d09e23fe): Found 1 empty unexpected parts (probably some dropped parts were not cleaned up before restart): [all_0_1_2] 2025.04.02 01:46:20.512962 [ 1425 ] {c3adc7bf-2f05-46dd-ab82-41bcd64d4ab2} executeQuery: Code: 36. DB::Exception: Second and third arguments must be ASCII strings: In scope SELECT translate('abc', 'Ãáéíóúôè', 'aaeiouoe'). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:53836) (comment: 02353_translate.sql) (in query: SELECT translate('abc', 'Ãáéíóúôè', 'aaeiouoe');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. DB::TranslateImpl::fillMapWithValues(std::array&, String const&, String const&) @ 0x000000001c0c29f4 5. DB::FunctionTranslate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0bbef0 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:46:20.514493 [ 1425 ] {} TCPHandler: Code: 36. DB::Exception: Second and third arguments must be ASCII strings: In scope SELECT translate('abc', 'Ãáéíóúôè', 'aaeiouoe'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. DB::TranslateImpl::fillMapWithValues(std::array&, String const&, String const&) @ 0x000000001c0c29f4 5. DB::FunctionTranslate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0bbef0 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:46:20.631135 [ 1425 ] {55599718-aecd-4747-b53b-02006d9e2a28} executeQuery: Code: 36. DB::Exception: Second and third arguments must be ASCII strings: In scope SELECT translate('aAbBcC', '中文内ç ', '12'). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:53836) (comment: 02353_translate.sql) (in query: SELECT translate('aAbBcC', '中文内ç ', '12');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. DB::TranslateImpl::fillMapWithValues(std::array&, String const&, String const&) @ 0x000000001c0c29f4 5. DB::FunctionTranslate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0bbef0 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:46:20.632421 [ 1425 ] {} TCPHandler: Code: 36. DB::Exception: Second and third arguments must be ASCII strings: In scope SELECT translate('aAbBcC', '中文内ç ', '12'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. DB::TranslateImpl::fillMapWithValues(std::array&, String const&, String const&) @ 0x000000001c0c29f4 5. DB::FunctionTranslate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0bbef0 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:46:22.084768 [ 1427 ] {d3d4a38f-8c52-4736-912e-d9aa8496bd0b} executeQuery: Code: 42. DB::Exception: Array data type family must have exactly one argument - type of elements. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48600) (comment: 00507_array_no_params.sh) (in query: CREATE TABLE foo (a Array) Engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/DataTypes/DataTypeArray.cpp:102: DB::create(std::shared_ptr const&) @ 0x0000000034bb261b 5. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000034bae59a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000034bf22d1 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:78: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x0000000034beb717 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:600: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x0000000037798a0a 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:656: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779a96b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:46:22.086821 [ 1427 ] {} TCPHandler: Code: 42. DB::Exception: Array data type family must have exactly one argument - type of elements. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/DataTypes/DataTypeArray.cpp:102: DB::create(std::shared_ptr const&) @ 0x0000000034bb261b 5. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000034bae59a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000034bf22d1 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:78: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x0000000034beb717 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:600: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x0000000037798a0a 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:656: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779a96b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:46:26.731594 [ 423 ] {ecdd8c16-2575-4d49-a2f4-f0a3b9fd475a} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:26.733458 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:26.746454 [ 423 ] {3ca5d2f2-55c7-4c6c-93e8-db24d78874ef} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y DEFAULT 2 REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y DEFAULT 2 REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:26.748230 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y DEFAULT 2 REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:26.760478 [ 423 ] {6eae6588-a03a-4471-a614-8e8e473b07e3} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y MATERIALIZED 3 REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y MATERIALIZED 3 REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:26.761911 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y MATERIALIZED 3 REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:26.773407 [ 423 ] {79742260-c105-4bd8-8c2a-52deebf6e7dd} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y EPHEMERAL 4 REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y EPHEMERAL 4 REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:26.774810 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y EPHEMERAL 4 REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:26.794772 [ 423 ] {691ea974-5260-4f52-b28a-8c87b1013ee3} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COMMENT \'5\' REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COMMENT \'5\' REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:26.798026 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COMMENT \'5\' REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:26.812990 [ 423 ] {9d96065d-a1b5-4a94-a790-211dd9e06e2f} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y CODEC(ZSTD) REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y CODEC(ZSTD) REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:26.815947 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y CODEC(ZSTD) REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:26.832544 [ 423 ] {8d67a115-d989-46ec-883c-85de8085d7c6} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y STATISTICS(tdigest) REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y STATISTICS(tdigest) REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:26.834032 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y STATISTICS(tdigest) REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:27.615166 [ 423 ] {db4c9ab5-89f8-49cb-a523-4f29e551538a} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 35 ('toDate'): toDate('2025-01-01') + toIntervalDay(x) REMOVE MATERIALIZED. Expected one of: COLLATE, DEFAULT, MATERIALIZED, ALIAS, EPHEMERAL, AUTO_INCREMENT, COMMENT, CODEC, STATISTICS, TTL, PRIMARY KEY, SETTINGS, REMOVE, MODIFY SETTING, RESET SETTING, FIRST, AFTER, token, Comma, INTO OUTFILE, FORMAT, end of query: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y TTL toDate(\'2025-01-01\') + toIntervalDay(x) REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y TTL toDate(\'2025-01-01\') + toIntervalDay(x) REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000895329e 3. ./build_docker/./src/Parsers/parseQuery.cpp:405: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c84a 4. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:46:27.616947 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Syntax error: failed at position 35 ('toDate'): toDate('2025-01-01') + toIntervalDay(x) REMOVE MATERIALIZED. Expected one of: COLLATE, DEFAULT, MATERIALIZED, ALIAS, EPHEMERAL, AUTO_INCREMENT, COMMENT, CODEC, STATISTICS, TTL, PRIMARY KEY, SETTINGS, REMOVE, MODIFY SETTING, RESET SETTING, FIRST, AFTER, token, Comma, INTO OUTFILE, FORMAT, end of query: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y TTL toDate(\'2025-01-01\') + toIntervalDay(x) REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000895329e 3. ./build_docker/./src/Parsers/parseQuery.cpp:405: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c84a 4. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:46:27.628116 [ 423 ] {09b908b5-62de-44e8-b22f-9a0b31f185ad} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 39 ('binary'): binary REMOVE MATERIALIZED. Expected one of: COLLATE, DEFAULT, MATERIALIZED, ALIAS, EPHEMERAL, AUTO_INCREMENT, COMMENT, CODEC, STATISTICS, TTL, PRIMARY KEY, SETTINGS, REMOVE, MODIFY SETTING, RESET SETTING, FIRST, AFTER, token, Comma, INTO OUTFILE, FORMAT, end of query: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COLLATE binary REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COLLATE binary REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000895329e 3. ./build_docker/./src/Parsers/parseQuery.cpp:405: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c84a 4. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:46:27.629691 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Syntax error: failed at position 39 ('binary'): binary REMOVE MATERIALIZED. Expected one of: COLLATE, DEFAULT, MATERIALIZED, ALIAS, EPHEMERAL, AUTO_INCREMENT, COMMENT, CODEC, STATISTICS, TTL, PRIMARY KEY, SETTINGS, REMOVE, MODIFY SETTING, RESET SETTING, FIRST, AFTER, token, Comma, INTO OUTFILE, FORMAT, end of query: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COLLATE binary REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000895329e 3. ./build_docker/./src/Parsers/parseQuery.cpp:405: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c84a 4. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:46:27.641663 [ 423 ] {78e0c64d-9434-463a-9aa4-c3313ff1b24d} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 65 ('='): = 20000) REMOVE MATERIALIZED. Expected one of: list, delimited by binary operators, literal, NULL, NULL, number, Bool, TRUE, FALSE, string literal, combination of maps, arrays, tuples, data type, identifier: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y SETTINGS (max_compress_block_size = 20000) REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y SETTINGS (max_compress_block_size = 20000) REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000895329e 3. ./build_docker/./src/Parsers/parseQuery.cpp:405: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c84a 4. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:46:27.643345 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Syntax error: failed at position 65 ('='): = 20000) REMOVE MATERIALIZED. Expected one of: list, delimited by binary operators, literal, NULL, NULL, number, Bool, TRUE, FALSE, string literal, combination of maps, arrays, tuples, data type, identifier: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y SETTINGS (max_compress_block_size = 20000) REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000895329e 3. ./build_docker/./src/Parsers/parseQuery.cpp:405: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c84a 4. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:46:27.654929 [ 423 ] {40bad694-7793-49bd-9365-f73c108dadda} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y PRIMARY KEY REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y PRIMARY KEY REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:27.656384 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y PRIMARY KEY REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:27.687859 [ 423 ] {579b9e66-9b3c-42e3-a1fc-2e52f94ef912} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 DEFAULT 2 REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 DEFAULT 2 REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:27.689469 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 DEFAULT 2 REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:27.693750 [ 422 ] {1d7691d2-fe26-4155-ae9d-7680611e9e68} executeQuery: Code: 53. DB::Exception: CAST AS Array can only be performed between same-dimensional Array, Map or String types. (TYPE_MISMATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48752) (comment: 03034_dynamic_conversions.sql) (in query: select number::Dynamic::Array(UInt64) as v from numbers(3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. DB::detail::FunctionCast::createArrayWrapper(std::shared_ptr const&, DB::DataTypeArray const&) const @ 0x0000000031e5c6fb 5. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000031e5540e 6. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000031e147a1 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000031e0ff88 8. DB::detail::FunctionCast::createDynamicToColumnWrapper(std::shared_ptr const&) const::'lambda'(std::vector>&, std::shared_ptr const&)::operator()(std::vector>&, std::shared_ptr const&) const @ 0x0000000031e2b73d 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr)>::__call_impl const&) const::'lambda'(std::vector>&, std::shared_ptr const&), COW::immutable_ptr (std::vector>&, std::shared_ptr)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr&&) @ 0x0000000031e2b38e 10. DB::detail::ConvertImplFromDynamicToColumn::execute(std::vector> const&, std::shared_ptr const&, unsigned long, std::function::immutable_ptr (std::vector>&, std::shared_ptr)> const&) @ 0x0000000008c39b1b 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000031e2b2a9 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 17. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000035b12641 18. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000035b0e123 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x00000000400e2457 20. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000040746adb 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000003867a61e 22. ./build_docker/./src/Planner/Planner.cpp:1656: DB::Planner::buildPlanForQueryNode() @ 0x0000000038662abb 23. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 27. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 28. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 2025.04.02 01:46:27.695667 [ 422 ] {} TCPHandler: Code: 53. DB::Exception: CAST AS Array can only be performed between same-dimensional Array, Map or String types. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. DB::detail::FunctionCast::createArrayWrapper(std::shared_ptr const&, DB::DataTypeArray const&) const @ 0x0000000031e5c6fb 5. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000031e5540e 6. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000031e147a1 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000031e0ff88 8. DB::detail::FunctionCast::createDynamicToColumnWrapper(std::shared_ptr const&) const::'lambda'(std::vector>&, std::shared_ptr const&)::operator()(std::vector>&, std::shared_ptr const&) const @ 0x0000000031e2b73d 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr)>::__call_impl const&) const::'lambda'(std::vector>&, std::shared_ptr const&), COW::immutable_ptr (std::vector>&, std::shared_ptr)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr&&) @ 0x0000000031e2b38e 10. DB::detail::ConvertImplFromDynamicToColumn::execute(std::vector> const&, std::shared_ptr const&, unsigned long, std::function::immutable_ptr (std::vector>&, std::shared_ptr)> const&) @ 0x0000000008c39b1b 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000031e2b2a9 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 17. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000035b12641 18. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000035b0e123 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x00000000400e2457 20. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000040746adb 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000003867a61e 22. ./build_docker/./src/Planner/Planner.cpp:1656: DB::Planner::buildPlanForQueryNode() @ 0x0000000038662abb 23. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 27. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 28. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 2025.04.02 01:46:27.700242 [ 423 ] {d2cd5e3f-7734-4416-95d3-62ce60108166} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 MATERIALIZED 3 REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 MATERIALIZED 3 REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:27.701622 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 MATERIALIZED 3 REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:27.712120 [ 423 ] {37819429-dd98-4744-81a3-405ec6300ab3} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 EPHEMERAL 4 REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 EPHEMERAL 4 REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:27.713569 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 EPHEMERAL 4 REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:27.723509 [ 423 ] {c354c95f-76d5-46ff-8b80-68bb6e6fbdc0} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COMMENT \'5\' REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COMMENT \'5\' REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:27.724856 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COMMENT \'5\' REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:27.734743 [ 423 ] {f729a023-6896-487b-8714-3bda9454c62f} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 CODEC(ZSTD) REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 CODEC(ZSTD) REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:27.736010 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 CODEC(ZSTD) REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:27.745580 [ 423 ] {a5661647-6371-4a7a-a7c6-c1f3f4693c6d} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 STATISTICS(tdigest) REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 STATISTICS(tdigest) REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:27.746928 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 STATISTICS(tdigest) REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:27.759290 [ 423 ] {6aac3b58-5f8e-4381-b529-348364e97ee7} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 TTL toDate(\'2025-01-01\') + toIntervalDay(x) REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 TTL toDate(\'2025-01-01\') + toIntervalDay(x) REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:27.760882 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 TTL toDate(\'2025-01-01\') + toIntervalDay(x) REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:27.772032 [ 423 ] {8292383e-2b35-4419-b3fb-c41efafaae26} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COLLATE binary REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COLLATE binary REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:27.773532 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COLLATE binary REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:27.785210 [ 423 ] {6604881b-2cfb-4926-9beb-cf3c0782dce3} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 SETTINGS (max_compress_block_size = 20000) REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 SETTINGS (max_compress_block_size = 20000) REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:27.786617 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 SETTINGS (max_compress_block_size = 20000) REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:27.797140 [ 423 ] {3be3a496-5c61-482c-af4d-86922c348f3a} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 PRIMARY KEY REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 PRIMARY KEY REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:27.798483 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 PRIMARY KEY REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:747: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c235c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.650184 [ 423 ] {a52f90e3-94a1-4858-b3d4-7f80dbad5d7a} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.652361 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.664350 [ 423 ] {3ecfd4da-d71a-4b00-b897-2475532dc34d} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y DEFAULT 2 MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y DEFAULT 2 MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.665917 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y DEFAULT 2 MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.676582 [ 423 ] {334df773-6ffe-40a3-8f0e-9138d56e671c} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y MATERIALIZED 3 MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y MATERIALIZED 3 MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.677930 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y MATERIALIZED 3 MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.688121 [ 423 ] {ce2c99e6-1c7d-4e53-862a-fb6c864fc0ca} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y EPHEMERAL 4 MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y EPHEMERAL 4 MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.689345 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y EPHEMERAL 4 MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.700372 [ 423 ] {36e16cd9-7b08-41dd-b39c-9665c39c35d5} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COMMENT \'5\' MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COMMENT \'5\' MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.701703 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COMMENT \'5\' MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.711552 [ 423 ] {2421b877-4a8c-45b5-ae2c-37d99e2edc57} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y CODEC(ZSTD) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y CODEC(ZSTD) MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.712710 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y CODEC(ZSTD) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.722763 [ 423 ] {5e0d3b36-0e85-4e90-9afb-6ad4b87580e0} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y STATISTICS(tdigest) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y STATISTICS(tdigest) MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.723995 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y STATISTICS(tdigest) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.733937 [ 423 ] {ace52df1-0dbf-4f14-88e4-f280ba3b3ddd} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 35 ('toDate'): toDate('2025-01-01') + toIntervalDay(x) MODIFY SETTING max_compress_block_size = 20000. Expected one of: COLLATE, DEFAULT, MATERIALIZED, ALIAS, EPHEMERAL, AUTO_INCREMENT, COMMENT, CODEC, STATISTICS, TTL, PRIMARY KEY, SETTINGS, REMOVE, MODIFY SETTING, RESET SETTING, FIRST, AFTER, token, Comma, INTO OUTFILE, FORMAT, end of query: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y TTL toDate(\'2025-01-01\') + toIntervalDay(x) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y TTL toDate(\'2025-01-01\') + toIntervalDay(x) MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000895329e 3. ./build_docker/./src/Parsers/parseQuery.cpp:405: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c84a 4. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:46:28.735442 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Syntax error: failed at position 35 ('toDate'): toDate('2025-01-01') + toIntervalDay(x) MODIFY SETTING max_compress_block_size = 20000. Expected one of: COLLATE, DEFAULT, MATERIALIZED, ALIAS, EPHEMERAL, AUTO_INCREMENT, COMMENT, CODEC, STATISTICS, TTL, PRIMARY KEY, SETTINGS, REMOVE, MODIFY SETTING, RESET SETTING, FIRST, AFTER, token, Comma, INTO OUTFILE, FORMAT, end of query: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y TTL toDate(\'2025-01-01\') + toIntervalDay(x) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000895329e 3. ./build_docker/./src/Parsers/parseQuery.cpp:405: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c84a 4. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:46:28.745071 [ 423 ] {01424c92-6a9a-4a83-8043-bdcfd41bdba7} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 39 ('binary'): binary MODIFY SETTING max_compress_block_size = 20000. Expected one of: COLLATE, DEFAULT, MATERIALIZED, ALIAS, EPHEMERAL, AUTO_INCREMENT, COMMENT, CODEC, STATISTICS, TTL, PRIMARY KEY, SETTINGS, REMOVE, MODIFY SETTING, RESET SETTING, FIRST, AFTER, token, Comma, INTO OUTFILE, FORMAT, end of query: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COLLATE binary MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COLLATE binary MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000895329e 3. ./build_docker/./src/Parsers/parseQuery.cpp:405: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c84a 4. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:46:28.746433 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Syntax error: failed at position 39 ('binary'): binary MODIFY SETTING max_compress_block_size = 20000. Expected one of: COLLATE, DEFAULT, MATERIALIZED, ALIAS, EPHEMERAL, AUTO_INCREMENT, COMMENT, CODEC, STATISTICS, TTL, PRIMARY KEY, SETTINGS, REMOVE, MODIFY SETTING, RESET SETTING, FIRST, AFTER, token, Comma, INTO OUTFILE, FORMAT, end of query: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COLLATE binary MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000895329e 3. ./build_docker/./src/Parsers/parseQuery.cpp:405: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c84a 4. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:46:28.756958 [ 423 ] {a77fbabe-844b-467d-9e23-fb4d9fea2e15} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 54 ('='): = 2) MODIFY SETTING max_compress_block_size = 20000. Expected one of: list, delimited by binary operators, literal, NULL, NULL, number, Bool, TRUE, FALSE, string literal, combination of maps, arrays, tuples, data type, identifier: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y SETTINGS (some_setting = 2) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y SETTINGS (some_setting = 2) MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000895329e 3. ./build_docker/./src/Parsers/parseQuery.cpp:405: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c84a 4. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:46:28.758216 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Syntax error: failed at position 54 ('='): = 2) MODIFY SETTING max_compress_block_size = 20000. Expected one of: list, delimited by binary operators, literal, NULL, NULL, number, Bool, TRUE, FALSE, string literal, combination of maps, arrays, tuples, data type, identifier: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y SETTINGS (some_setting = 2) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000895329e 3. ./build_docker/./src/Parsers/parseQuery.cpp:405: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c84a 4. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:46:28.767721 [ 423 ] {6fef634d-3bdb-4be2-8aaa-0c2621c46649} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y PRIMARY KEY MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y PRIMARY KEY MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.768875 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y PRIMARY KEY MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.801472 [ 423 ] {0cdb1112-fce2-4846-8e96-a13bf7693668} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 DEFAULT 2 MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 DEFAULT 2 MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.802902 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 DEFAULT 2 MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.812910 [ 423 ] {e4cf460e-32bf-493c-8125-342c7b80476a} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 MATERIALIZED 3 MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 MATERIALIZED 3 MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.814494 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 MATERIALIZED 3 MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.823807 [ 423 ] {6855ec30-8025-4d98-8d89-1a6cc4895873} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 EPHEMERAL 4 MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 EPHEMERAL 4 MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.825124 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 EPHEMERAL 4 MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.835230 [ 423 ] {b5e31150-9f42-4dc9-8438-a8f9b73d35e7} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COMMENT \'5\' MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COMMENT \'5\' MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.836854 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COMMENT \'5\' MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.850051 [ 423 ] {bd769a3d-107a-4bfd-a060-d81be5c36dce} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 CODEC(ZSTD) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 CODEC(ZSTD) MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.851736 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 CODEC(ZSTD) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.863794 [ 423 ] {4cc55f7b-e02f-428b-865c-1685988dea65} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 STATISTICS(tdigest) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 STATISTICS(tdigest) MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.865487 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 STATISTICS(tdigest) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.878018 [ 423 ] {3d230837-5185-4d4d-b037-1c30768a2ba6} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 TTL toDate(\'2025-01-01\') + toIntervalDay(x) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 TTL toDate(\'2025-01-01\') + toIntervalDay(x) MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.879548 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 TTL toDate(\'2025-01-01\') + toIntervalDay(x) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.889886 [ 423 ] {1a0da137-d4c0-4110-8c17-43b760f9bacd} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COLLATE binary MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COLLATE binary MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.891930 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COLLATE binary MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.908067 [ 423 ] {d18424f7-2fe3-44c2-9cfa-83633bbf895a} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 SETTINGS (some_setting = 2) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 SETTINGS (some_setting = 2) MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.910258 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 SETTINGS (some_setting = 2) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.922093 [ 423 ] {78f523e9-d2f6-4cbc-a616-fd4e01b9e0e2} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 PRIMARY KEY MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 PRIMARY KEY MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:28.923951 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 PRIMARY KEY MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:768: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c259c 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:29.248553 [ 422 ] {4612ca84-9619-4326-a97f-ab3d47018e64} executeQuery: Code: 6. DB::Exception: Cannot parse string '42.42' as UInt64: syntax error at position 2 (parsed just '42'). Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION CAST(__table1.d :: 2, 'UInt64'_String :: 1) -> CAST(__table1.d, 'UInt64'_String) UInt64 : 0'. (CANNOT_PARSE_TEXT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48752) (comment: 03034_dynamic_conversions.sql) (in query: select d::UInt64 from test;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000008c649a2 4. ./src/Functions/FunctionsConversion.h:1040: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000003262fb6e 5. ./src/Functions/FunctionsConversion.h:1578: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000326187e7 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000324aa879 7. ./src/Functions/FunctionsConversion.h:2511: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003252cb09 8. ./src/Functions/FunctionsConversion.h:2292: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003252b702 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000031eab4c9 15. DB::detail::FunctionCast::createDynamicToColumnWrapper(std::shared_ptr const&) const::'lambda'(std::vector>&, std::shared_ptr const&)::operator()(std::vector>&, std::shared_ptr const&) const @ 0x0000000031e2b8ea 16. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr)>::__call_impl const&) const::'lambda'(std::vector>&, std::shared_ptr const&), COW::immutable_ptr (std::vector>&, std::shared_ptr)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr&&) @ 0x0000000031e2b38e 17. DB::detail::ConvertImplFromDynamicToColumn::execute(std::vector> const&, std::shared_ptr const&, unsigned long, std::function::immutable_ptr (std::vector>&, std::shared_ptr)> const&) @ 0x0000000008c39b1b 18. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000031e2b2a9 19. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 23. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 24. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x00000000400e3001 25. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027d13b04 26. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003f6df04b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003f71c8c3 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c2f5 31. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 2025.04.02 01:46:29.251359 [ 422 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '42.42' as UInt64: syntax error at position 2 (parsed just '42'). Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION CAST(__table1.d :: 2, 'UInt64'_String :: 1) -> CAST(__table1.d, 'UInt64'_String) UInt64 : 0'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000008c649a2 4. ./src/Functions/FunctionsConversion.h:1040: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000003262fb6e 5. ./src/Functions/FunctionsConversion.h:1578: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000326187e7 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000324aa879 7. ./src/Functions/FunctionsConversion.h:2511: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003252cb09 8. ./src/Functions/FunctionsConversion.h:2292: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003252b702 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000031eab4c9 15. DB::detail::FunctionCast::createDynamicToColumnWrapper(std::shared_ptr const&) const::'lambda'(std::vector>&, std::shared_ptr const&)::operator()(std::vector>&, std::shared_ptr const&) const @ 0x0000000031e2b8ea 16. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr)>::__call_impl const&) const::'lambda'(std::vector>&, std::shared_ptr const&), COW::immutable_ptr (std::vector>&, std::shared_ptr)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr&&) @ 0x0000000031e2b38e 17. DB::detail::ConvertImplFromDynamicToColumn::execute(std::vector> const&, std::shared_ptr const&, unsigned long, std::function::immutable_ptr (std::vector>&, std::shared_ptr)> const&) @ 0x0000000008c39b1b 18. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000031e2b2a9 19. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 23. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 24. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x00000000400e3001 25. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027d13b04 26. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003f6df04b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003f71c8c3 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c2f5 31. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 2025.04.02 01:46:29.795179 [ 423 ] {3a1e2926-1c03-4a79-b83b-e058155d2c79} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:29.797262 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:29.810548 [ 423 ] {d238960a-e43d-467a-9a85-7eacd1639d03} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y DEFAULT 2 RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y DEFAULT 2 RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:29.812155 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y DEFAULT 2 RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:29.823851 [ 423 ] {8ecb9217-03ce-4bde-b308-33b5625cec25} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y MATERIALIZED 3 RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y MATERIALIZED 3 RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:29.825537 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y MATERIALIZED 3 RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:29.837707 [ 423 ] {15afee90-40dc-4c5d-ae77-2e117b5c9dde} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y EPHEMERAL 4 RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y EPHEMERAL 4 RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:29.839394 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y EPHEMERAL 4 RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:29.851455 [ 423 ] {fe5308a8-28f5-4e12-8495-4859967b7e07} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COMMENT \'5\' RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COMMENT \'5\' RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:29.853018 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COMMENT \'5\' RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:29.864373 [ 423 ] {b8dd7a94-4c17-4c67-9510-dfad2edc0935} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y CODEC(ZSTD) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y CODEC(ZSTD) RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:29.866070 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y CODEC(ZSTD) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:29.876717 [ 423 ] {c235c07f-0f35-46ad-bacc-7293188cd0a7} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y STATISTICS(tdigest) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y STATISTICS(tdigest) RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:29.878284 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y STATISTICS(tdigest) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:29.888202 [ 423 ] {f32c767f-d3c9-4ea8-8b2d-d6143a9c63cf} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 35 ('toDate'): toDate('2025-01-01') + toIntervalDay(x) RESET SETTING max_compress_block_size. Expected one of: COLLATE, DEFAULT, MATERIALIZED, ALIAS, EPHEMERAL, AUTO_INCREMENT, COMMENT, CODEC, STATISTICS, TTL, PRIMARY KEY, SETTINGS, REMOVE, MODIFY SETTING, RESET SETTING, FIRST, AFTER, token, Comma, INTO OUTFILE, FORMAT, end of query: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y TTL toDate(\'2025-01-01\') + toIntervalDay(x) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y TTL toDate(\'2025-01-01\') + toIntervalDay(x) RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000895329e 3. ./build_docker/./src/Parsers/parseQuery.cpp:405: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c84a 4. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:46:29.889613 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Syntax error: failed at position 35 ('toDate'): toDate('2025-01-01') + toIntervalDay(x) RESET SETTING max_compress_block_size. Expected one of: COLLATE, DEFAULT, MATERIALIZED, ALIAS, EPHEMERAL, AUTO_INCREMENT, COMMENT, CODEC, STATISTICS, TTL, PRIMARY KEY, SETTINGS, REMOVE, MODIFY SETTING, RESET SETTING, FIRST, AFTER, token, Comma, INTO OUTFILE, FORMAT, end of query: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y TTL toDate(\'2025-01-01\') + toIntervalDay(x) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000895329e 3. ./build_docker/./src/Parsers/parseQuery.cpp:405: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c84a 4. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:46:29.899452 [ 423 ] {971c764f-9650-4183-b9d4-b89e682d66c8} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 39 ('binary'): binary RESET SETTING max_compress_block_size. Expected one of: COLLATE, DEFAULT, MATERIALIZED, ALIAS, EPHEMERAL, AUTO_INCREMENT, COMMENT, CODEC, STATISTICS, TTL, PRIMARY KEY, SETTINGS, REMOVE, MODIFY SETTING, RESET SETTING, FIRST, AFTER, token, Comma, INTO OUTFILE, FORMAT, end of query: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COLLATE binary RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COLLATE binary RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000895329e 3. ./build_docker/./src/Parsers/parseQuery.cpp:405: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c84a 4. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:46:29.900844 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Syntax error: failed at position 39 ('binary'): binary RESET SETTING max_compress_block_size. Expected one of: COLLATE, DEFAULT, MATERIALIZED, ALIAS, EPHEMERAL, AUTO_INCREMENT, COMMENT, CODEC, STATISTICS, TTL, PRIMARY KEY, SETTINGS, REMOVE, MODIFY SETTING, RESET SETTING, FIRST, AFTER, token, Comma, INTO OUTFILE, FORMAT, end of query: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COLLATE binary RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000895329e 3. ./build_docker/./src/Parsers/parseQuery.cpp:405: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c84a 4. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:46:29.910681 [ 423 ] {6d7430c3-354f-49b8-a3d1-3ecabdaa5119} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 54 ('='): = 2) RESET SETTING max_compress_block_size. Expected one of: list, delimited by binary operators, literal, NULL, NULL, number, Bool, TRUE, FALSE, string literal, combination of maps, arrays, tuples, data type, identifier: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y SETTINGS (some_setting = 2) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y SETTINGS (some_setting = 2) RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000895329e 3. ./build_docker/./src/Parsers/parseQuery.cpp:405: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c84a 4. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:46:29.912111 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Syntax error: failed at position 54 ('='): = 2) RESET SETTING max_compress_block_size. Expected one of: list, delimited by binary operators, literal, NULL, NULL, number, Bool, TRUE, FALSE, string literal, combination of maps, arrays, tuples, data type, identifier: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y SETTINGS (some_setting = 2) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000895329e 3. ./build_docker/./src/Parsers/parseQuery.cpp:405: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c84a 4. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:46:29.922020 [ 423 ] {10f81161-4d16-45a5-b407-a1f0aad0ec37} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y PRIMARY KEY RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y PRIMARY KEY RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:29.923419 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y PRIMARY KEY RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:29.955725 [ 423 ] {0ec8906c-e660-4434-9fbe-f63cb4ea496c} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 DEFAULT 2 RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 DEFAULT 2 RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:29.957328 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 DEFAULT 2 RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:29.967864 [ 423 ] {9d0d43bf-b231-4d9a-9f29-ae867e11ec5c} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 MATERIALIZED 3 RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 MATERIALIZED 3 RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:29.969308 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 MATERIALIZED 3 RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:29.980239 [ 423 ] {63545aee-b7c7-4f2c-b722-f8ab39660f92} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 EPHEMERAL 4 RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 EPHEMERAL 4 RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:29.981638 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 EPHEMERAL 4 RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:29.991809 [ 423 ] {ba427ff9-bf8a-4a46-99ea-7c1ce28d7bfa} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COMMENT \'5\' RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COMMENT \'5\' RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:29.993275 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COMMENT \'5\' RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:30.003830 [ 423 ] {783ef5cf-b9f2-4c2a-a5d9-a8888491bf0f} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 CODEC(ZSTD) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 CODEC(ZSTD) RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:30.005450 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 CODEC(ZSTD) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:30.016565 [ 423 ] {bd666d8f-f8fc-4f97-928a-6fd648112a9b} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 STATISTICS(tdigest) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 STATISTICS(tdigest) RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:30.018138 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 STATISTICS(tdigest) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:30.029107 [ 423 ] {d50cb5e1-fe77-458e-9f18-c78a770f2005} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 TTL toDate(\'2025-01-01\') + toIntervalDay(x) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 TTL toDate(\'2025-01-01\') + toIntervalDay(x) RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:30.030546 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 TTL toDate(\'2025-01-01\') + toIntervalDay(x) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:30.040827 [ 423 ] {ec53f7e2-d2b2-4885-8d94-f768bd600463} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COLLATE binary RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COLLATE binary RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:30.042350 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COLLATE binary RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:30.053049 [ 423 ] {0a4d1e05-de8c-48dc-b86f-4e5f37de972b} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 SETTINGS (some_setting = 2) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 SETTINGS (some_setting = 2) RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:30.054438 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 SETTINGS (some_setting = 2) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:30.064451 [ 423 ] {76deba99-9ddb-4d7c-932b-bf4a59cc0583} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 PRIMARY KEY RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48710) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 PRIMARY KEY RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:30.066004 [ 423 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 PRIMARY KEY RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000001b2dc72a 4. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:741: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x00000000425c4ac7 5. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:775: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c27ca 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 7. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1010: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c5249 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 9. ./build_docker/./src/Parsers/ParserAlterQuery.cpp:1063: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425c6519 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 11. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004264fdbf 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 13. ./build_docker/./src/Parsers/ParserQuery.cpp:82: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000004263c5f6 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000425b03f2 15. ./build_docker/./src/Parsers/parseQuery.cpp:315: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042708f95 16. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 17. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 18. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3715b1 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 22. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 2025.04.02 01:46:30.088800 [ 2377 ] {83302b64-6221-4664-afbc-cf56c9f940d1} executeQuery: Code: 258. DB::Exception: Different number of columns in UNION_ALL elements: c1, c2, c3 and c1, c2. (UNION_ALL_RESULT_STRUCTURES_MISMATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52664) (comment: 01036_union_different_columns.sql) (in query: select 1 as c1, 2 as c2, 3 as c3 union all (select 1 as c1, 2 as c2, 3 as c3 union all select 1 as c1, 2 as c2) -- { serverError UNION_ALL_RESULT_STRUCTURES_MISMATCH } ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&&) @ 0x0000000035c65677 4. ./build_docker/./src/Planner/Utils.cpp:118: DB::buildCommonHeaderForUnion(std::vector> const&, DB::SelectUnionMode) @ 0x0000000035c58a49 5. ./build_docker/./src/Planner/Planner.cpp:1366: DB::Planner::buildPlanForUnionNode() @ 0x000000003865048e 6. ./build_docker/./src/Planner/Planner.cpp:1313: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e2 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 10. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 11. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 17. ? @ 0x00007f583d9b1ac3 18. ? @ 0x00007f583da43850 2025.04.02 01:46:30.090453 [ 2377 ] {} TCPHandler: Code: 258. DB::Exception: Different number of columns in UNION_ALL elements: c1, c2, c3 and c1, c2. (UNION_ALL_RESULT_STRUCTURES_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&&) @ 0x0000000035c65677 4. ./build_docker/./src/Planner/Utils.cpp:118: DB::buildCommonHeaderForUnion(std::vector> const&, DB::SelectUnionMode) @ 0x0000000035c58a49 5. ./build_docker/./src/Planner/Planner.cpp:1366: DB::Planner::buildPlanForUnionNode() @ 0x000000003865048e 6. ./build_docker/./src/Planner/Planner.cpp:1313: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e2 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 10. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 11. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 17. ? @ 0x00007f583d9b1ac3 18. ? @ 0x00007f583da43850 2025.04.02 01:46:30.514994 [ 422 ] {f1cb6e4b-d9af-4084-b756-448bd8105ecd} executeQuery: Code: 38. DB::Exception: Cannot parse date: value is too short: Cannot parse Date from String: while executing 'FUNCTION CAST(__table1.d :: 2, 'Date'_String :: 1) -> CAST(__table1.d, 'Date'_String) Date : 0'. (CANNOT_PARSE_DATE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48752) (comment: 03034_dynamic_conversions.sql) (in query: select d::Date from test;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/IO/ReadHelpers.cpp:1363: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002087869b 5. ./src/IO/ReadHelpers.h:825: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000027db3553 6. ./src/IO/ReadHelpers.h:846: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000003280146d 7. ./src/Functions/FunctionsConversion.h:1578: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000327d8127 8. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000324f630b 9. ./src/Functions/FunctionsConversion.h:2511: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003255ef49 10. ./src/Functions/FunctionsConversion.h:2292: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003255db42 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 15. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 16. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000031eab4c9 17. DB::detail::FunctionCast::createDynamicToColumnWrapper(std::shared_ptr const&) const::'lambda'(std::vector>&, std::shared_ptr const&)::operator()(std::vector>&, std::shared_ptr const&) const @ 0x0000000031e2b8ea 18. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr)>::__call_impl const&) const::'lambda'(std::vector>&, std::shared_ptr const&), COW::immutable_ptr (std::vector>&, std::shared_ptr)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr&&) @ 0x0000000031e2b38e 19. DB::detail::ConvertImplFromDynamicToColumn::execute(std::vector> const&, std::shared_ptr const&, unsigned long, std::function::immutable_ptr (std::vector>&, std::shared_ptr)> const&) @ 0x0000000008c39b1b 20. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000031e2b2a9 21. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 22. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 23. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 24. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 25. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 26. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x00000000400e3001 27. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027d13b04 28. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003f6df04b 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003f71c8c3 2025.04.02 01:46:30.517080 [ 422 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date: value is too short: Cannot parse Date from String: while executing 'FUNCTION CAST(__table1.d :: 2, 'Date'_String :: 1) -> CAST(__table1.d, 'Date'_String) Date : 0'. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/IO/ReadHelpers.cpp:1363: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000002087869b 5. ./src/IO/ReadHelpers.h:825: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000027db3553 6. ./src/IO/ReadHelpers.h:846: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000003280146d 7. ./src/Functions/FunctionsConversion.h:1578: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000327d8127 8. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000324f630b 9. ./src/Functions/FunctionsConversion.h:2511: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003255ef49 10. ./src/Functions/FunctionsConversion.h:2292: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003255db42 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 15. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 16. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000031eab4c9 17. DB::detail::FunctionCast::createDynamicToColumnWrapper(std::shared_ptr const&) const::'lambda'(std::vector>&, std::shared_ptr const&)::operator()(std::vector>&, std::shared_ptr const&) const @ 0x0000000031e2b8ea 18. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr)>::__call_impl const&) const::'lambda'(std::vector>&, std::shared_ptr const&), COW::immutable_ptr (std::vector>&, std::shared_ptr)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr&&) @ 0x0000000031e2b38e 19. DB::detail::ConvertImplFromDynamicToColumn::execute(std::vector> const&, std::shared_ptr const&, unsigned long, std::function::immutable_ptr (std::vector>&, std::shared_ptr)> const&) @ 0x0000000008c39b1b 20. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000031e2b2a9 21. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 22. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 23. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 24. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 25. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 26. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x00000000400e3001 27. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027d13b04 28. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003f6df04b 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003f71c8c3 2025.04.02 01:46:32.624497 [ 423 ] {11df5b4b-0ea1-4819-b406-38ba7508a3b4} executeQuery: Code: 469. DB::Exception: Constraint `b_constraint` for table test_cy84582n.test_constraints (7321f3c8-b53f-4cef-87b2-2fe6c1306311) is violated at row 1. Expression: (b > 0). Column values: b = 0. (VIOLATED_CONSTRAINT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52798) (comment: 00953_constraints_operations.sh) (in query: INSERT INTO test_constraints VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000034f78a67 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x00000000400aa208 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x00000000400e14d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000400e0ff6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x00000000400dfcc7 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003f76f0ba 12. ./build_docker/./src/Server/TCPHandler.cpp:1122: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003f44ec83 13. ./build_docker/./src/Server/TCPHandler.cpp:665: DB::TCPHandler::runImpl() @ 0x000000003f42c409 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 20. ? @ 0x00007f583d9b1ac3 21. ? @ 0x00007f583da43850 2025.04.02 01:46:32.628708 [ 423 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `b_constraint` for table test_cy84582n.test_constraints (7321f3c8-b53f-4cef-87b2-2fe6c1306311) is violated at row 1. Expression: (b > 0). Column values: b = 0. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000034f78a67 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x00000000400aa208 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x00000000400e14d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000400e0ff6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x00000000400dfcc7 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003f76f0ba 12. ./build_docker/./src/Server/TCPHandler.cpp:1122: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003f44ec83 13. ./build_docker/./src/Server/TCPHandler.cpp:665: DB::TCPHandler::runImpl() @ 0x000000003f42c409 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 20. ? @ 0x00007f583d9b1ac3 21. ? @ 0x00007f583da43850 2025.04.02 01:46:35.013493 [ 2377 ] {a4f95a12-b0d2-4ffd-b9f4-b4b813b26d1d} executeQuery: Code: 127. DB::Exception: Indexes of type 'annoy' or 'usearch' are no longer supported. Please drop and recreate the index as type 'vector_similarity'. (ILLEGAL_INDEX) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52914) (comment: 02354_vector_search_legacy_index_compatibility.sql) (in query: INSERT INTO tab VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexLegacyVectorSimilarity.cpp:23: DB::MergeTreeIndexLegacyVectorSimilarity::createIndexAggregator(DB::MergeTreeWriterSettings const&) const @ 0x000000003e3d3cac 5. ./src/Storages/MergeTree/MergeTreeIndices.h:177: DB::IMergeTreeIndex::createIndexAggregatorForPart(std::shared_ptr const&, DB::MergeTreeWriterSettings const&) const @ 0x000000003e2b288e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:307: DB::MergeTreeDataPartWriterOnDisk::initSkipIndices() @ 0x000000003e14d63d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:204: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003e14a348 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:29: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003e12aec8 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003e0f7075 10. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:191: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003ddbc99d 11. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:65: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003e62469f 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x000000003e22e9db 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:481: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003e2240d7 14. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003eb8ae0e 15. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:18: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000040447b99 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x00000000400e14d9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000400e0ff6 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x00000000400dfcc7 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 22. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003f76f0ba 23. ./build_docker/./src/Server/TCPHandler.cpp:1122: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003f44ec83 24. ./build_docker/./src/Server/TCPHandler.cpp:665: DB::TCPHandler::runImpl() @ 0x000000003f42c409 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:46:35.015867 [ 2377 ] {} TCPHandler: Code: 127. DB::Exception: Indexes of type 'annoy' or 'usearch' are no longer supported. Please drop and recreate the index as type 'vector_similarity'. (ILLEGAL_INDEX), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexLegacyVectorSimilarity.cpp:23: DB::MergeTreeIndexLegacyVectorSimilarity::createIndexAggregator(DB::MergeTreeWriterSettings const&) const @ 0x000000003e3d3cac 5. ./src/Storages/MergeTree/MergeTreeIndices.h:177: DB::IMergeTreeIndex::createIndexAggregatorForPart(std::shared_ptr const&, DB::MergeTreeWriterSettings const&) const @ 0x000000003e2b288e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:307: DB::MergeTreeDataPartWriterOnDisk::initSkipIndices() @ 0x000000003e14d63d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:204: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003e14a348 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:29: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003e12aec8 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003e0f7075 10. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:191: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003ddbc99d 11. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:65: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003e62469f 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x000000003e22e9db 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:481: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003e2240d7 14. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003eb8ae0e 15. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:18: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000040447b99 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x00000000400e14d9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000400e0ff6 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x00000000400dfcc7 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 22. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003f76f0ba 23. ./build_docker/./src/Server/TCPHandler.cpp:1122: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003f44ec83 24. ./build_docker/./src/Server/TCPHandler.cpp:665: DB::TCPHandler::runImpl() @ 0x000000003f42c409 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:46:35.205294 [ 2377 ] {6c4cf0b8-3166-43b9-8c44-65b2a4b9b4a2} executeQuery: Code: 127. DB::Exception: Indexes of type 'annoy' or 'usearch' are no longer supported. Please drop and recreate the index as type 'vector_similarity'. (ILLEGAL_INDEX) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52914) (comment: 02354_vector_search_legacy_index_compatibility.sql) (in query: INSERT INTO tab VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexLegacyVectorSimilarity.cpp:23: DB::MergeTreeIndexLegacyVectorSimilarity::createIndexAggregator(DB::MergeTreeWriterSettings const&) const @ 0x000000003e3d3cac 5. ./src/Storages/MergeTree/MergeTreeIndices.h:177: DB::IMergeTreeIndex::createIndexAggregatorForPart(std::shared_ptr const&, DB::MergeTreeWriterSettings const&) const @ 0x000000003e2b288e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:307: DB::MergeTreeDataPartWriterOnDisk::initSkipIndices() @ 0x000000003e14d63d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:204: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003e14a348 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:29: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003e12aec8 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003e0f7075 10. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:191: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003ddbc99d 11. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:65: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003e62469f 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x000000003e22e9db 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:481: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003e2240d7 14. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003eb8ae0e 15. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:18: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000040447b99 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x00000000400e14d9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000400e0ff6 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x00000000400dfcc7 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 22. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003f76f0ba 23. ./build_docker/./src/Server/TCPHandler.cpp:1122: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003f44ec83 24. ./build_docker/./src/Server/TCPHandler.cpp:665: DB::TCPHandler::runImpl() @ 0x000000003f42c409 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:46:35.207809 [ 2377 ] {} TCPHandler: Code: 127. DB::Exception: Indexes of type 'annoy' or 'usearch' are no longer supported. Please drop and recreate the index as type 'vector_similarity'. (ILLEGAL_INDEX), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexLegacyVectorSimilarity.cpp:23: DB::MergeTreeIndexLegacyVectorSimilarity::createIndexAggregator(DB::MergeTreeWriterSettings const&) const @ 0x000000003e3d3cac 5. ./src/Storages/MergeTree/MergeTreeIndices.h:177: DB::IMergeTreeIndex::createIndexAggregatorForPart(std::shared_ptr const&, DB::MergeTreeWriterSettings const&) const @ 0x000000003e2b288e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:307: DB::MergeTreeDataPartWriterOnDisk::initSkipIndices() @ 0x000000003e14d63d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:204: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003e14a348 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:29: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003e12aec8 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003e0f7075 10. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:191: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003ddbc99d 11. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:65: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003e62469f 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x000000003e22e9db 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:481: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003e2240d7 14. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003eb8ae0e 15. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:18: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000040447b99 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x00000000400e14d9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000400e0ff6 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x00000000400dfcc7 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 22. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003f76f0ba 23. ./build_docker/./src/Server/TCPHandler.cpp:1122: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003f44ec83 24. ./build_docker/./src/Server/TCPHandler.cpp:665: DB::TCPHandler::runImpl() @ 0x000000003f42c409 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:46:36.465642 [ 2377 ] {3206e1cd-7f4b-4f2e-947b-d57b17dcec9f} executeQuery: Code: 469. DB::Exception: Constraint `b_constraint` for table test_cy84582n.test_constraints (7321f3c8-b53f-4cef-87b2-2fe6c1306311) is violated at row 1. Expression: (b > 10). Column values: b = 10. (VIOLATED_CONSTRAINT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:53004) (comment: 00953_constraints_operations.sh) (in query: INSERT INTO test_constraints VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000034f78a67 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x00000000400aa208 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x00000000400e14d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000400e0ff6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x00000000400dfcc7 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003f76f0ba 12. ./build_docker/./src/Server/TCPHandler.cpp:1122: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003f44ec83 13. ./build_docker/./src/Server/TCPHandler.cpp:665: DB::TCPHandler::runImpl() @ 0x000000003f42c409 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 20. ? @ 0x00007f583d9b1ac3 21. ? @ 0x00007f583da43850 2025.04.02 01:46:36.468635 [ 2377 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `b_constraint` for table test_cy84582n.test_constraints (7321f3c8-b53f-4cef-87b2-2fe6c1306311) is violated at row 1. Expression: (b > 10). Column values: b = 10. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000034f78a67 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x00000000400aa208 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x00000000400e14d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000400e0ff6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x00000000400dfcc7 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003f76f0ba 12. ./build_docker/./src/Server/TCPHandler.cpp:1122: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003f44ec83 13. ./build_docker/./src/Server/TCPHandler.cpp:665: DB::TCPHandler::runImpl() @ 0x000000003f42c409 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 20. ? @ 0x00007f583d9b1ac3 21. ? @ 0x00007f583da43850 2025.04.02 01:46:39.601646 [ 3098 ] {68fe3a98-f7d4-4a2f-b500-76ae04346be8} test_d2f129d7.rmt1 (0419d31d-2ad6-481b-abd8-cf78ca931850): Part /var/lib/clickhouse/store/041/0419d31d-2ad6-481b-abd8-cf78ca931850/all_0_0_0_1/ is broken and needs manual correction. Reason: Code: 107. DB::Exception: store/041/0419d31d-2ad6-481b-abd8-cf78ca931850/all_0_0_0_1/data.bin doesn't exist: columns: columns format version: 1 2 columns: `a` Int32 `b` Int32 , getMarkSizeInBytes: 40, getMarksCount: 2, index_granularity_info: [mark_type: [adaptive: true, compressed: true, part_type: Compact], index_granularity_bytes: 10627972, fixed_index_granularity: 15428], index_granularity: [Constant(constant_granularity: 3, last_mark_granularity: 3, num_marks_without_final: 1, has_final_mark: true)], part_state: [state: Temporary, is_unexpected_local_part: false, is_frozen: false, is_duplicate: false]. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type>, std::__fs::filesystem::path&&) @ 0x000000003e0cd02a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartChecksum.cpp:73: DB::MergeTreeDataPartChecksum::checkSize(DB::IDataPartStorage const&, String const&) const @ 0x000000003e0d1b2d 5. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:2297: DB::IMergeTreeDataPart::checkConsistencyBase() const @ 0x000000003db7a551 6. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:2355: DB::IMergeTreeDataPart::checkConsistency(bool) const @ 0x000000003db4c0fe 7. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:844: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x000000003db3bdea 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1579: DB::MergeTreeData::loadDataPart(DB::MergeTreePartInfo const&, String const&, std::shared_ptr const&, DB::MergeTreeDataPartState, std::mutex&) @ 0x000000003de22de3 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1718: DB::MergeTreeData::loadDataPartWithRetries(DB::MergeTreePartInfo const&, String const&, std::shared_ptr const&, DB::MergeTreeDataPartState, std::mutex&, unsigned long, unsigned long, unsigned long) @ 0x000000003de3383c 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1780: void std::__function::__policy_invoker::__call_impl, std::allocator>>&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003e01391d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000027a374ac 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000027a3728d 13. ./contrib/llvm-project/libcxx/include/future:1876: std::packaged_task::operator()() @ 0x0000000027a39b9d 14. ./src/Common/threadPoolCallbackRunner.h:167: void std::__function::__policy_invoker::__call_impl>, std::function>::operator()(std::function&&, Priority)::'lambda0'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000027a39a0e 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002097cef4 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002098fd26 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002098fadf 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 20. ? @ 0x00007f583d9b1ac3 21. ? @ 0x00007f583da43850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:46:39.603299 [ 3098 ] {68fe3a98-f7d4-4a2f-b500-76ae04346be8} test_d2f129d7.rmt1 (0419d31d-2ad6-481b-abd8-cf78ca931850): while loading part all_0_0_0_1 on path store/041/0419d31d-2ad6-481b-abd8-cf78ca931850/all_0_0_0_1: Code: 107. DB::Exception: store/041/0419d31d-2ad6-481b-abd8-cf78ca931850/all_0_0_0_1/data.bin doesn't exist: columns: columns format version: 1 2 columns: `a` Int32 `b` Int32 , getMarkSizeInBytes: 40, getMarksCount: 2, index_granularity_info: [mark_type: [adaptive: true, compressed: true, part_type: Compact], index_granularity_bytes: 10627972, fixed_index_granularity: 15428], index_granularity: [Constant(constant_granularity: 3, last_mark_granularity: 3, num_marks_without_final: 1, has_final_mark: true)], part_state: [state: Temporary, is_unexpected_local_part: false, is_frozen: false, is_duplicate: false]: Part contains files: data.cmrk3 (58 bytes), primary.cidx (42 bytes), count.txt (1 bytes), serialization.json (145 bytes), checksums.txt (259 bytes), default_compression_codec.txt (10 bytes), columns.txt (57 bytes), metadata_version.txt (1 bytes). (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type>, std::__fs::filesystem::path&&) @ 0x000000003e0cd02a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartChecksum.cpp:73: DB::MergeTreeDataPartChecksum::checkSize(DB::IDataPartStorage const&, String const&) const @ 0x000000003e0d1b2d 5. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:2297: DB::IMergeTreeDataPart::checkConsistencyBase() const @ 0x000000003db7a551 6. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:2355: DB::IMergeTreeDataPart::checkConsistency(bool) const @ 0x000000003db4c0fe 7. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:844: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x000000003db3bdea 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1579: DB::MergeTreeData::loadDataPart(DB::MergeTreePartInfo const&, String const&, std::shared_ptr const&, DB::MergeTreeDataPartState, std::mutex&) @ 0x000000003de22de3 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1718: DB::MergeTreeData::loadDataPartWithRetries(DB::MergeTreePartInfo const&, String const&, std::shared_ptr const&, DB::MergeTreeDataPartState, std::mutex&, unsigned long, unsigned long, unsigned long) @ 0x000000003de3383c 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1780: void std::__function::__policy_invoker::__call_impl, std::allocator>>&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003e01391d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000027a374ac 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000027a3728d 13. ./contrib/llvm-project/libcxx/include/future:1876: std::packaged_task::operator()() @ 0x0000000027a39b9d 14. ./src/Common/threadPoolCallbackRunner.h:167: void std::__function::__policy_invoker::__call_impl>, std::function>::operator()(std::function&&, Priority)::'lambda0'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000027a39a0e 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002097cef4 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002098fd26 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002098fadf 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 20. ? @ 0x00007f583d9b1ac3 21. ? @ 0x00007f583da43850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:46:39.604144 [ 3098 ] {68fe3a98-f7d4-4a2f-b500-76ae04346be8} test_d2f129d7.rmt1 (0419d31d-2ad6-481b-abd8-cf78ca931850): Detaching broken part /var/lib/clickhouse/store/041/0419d31d-2ad6-481b-abd8-cf78ca931850/all_0_0_0_1 (size: 573.00 B). If it happened after update, it is likely because of backward incompatibility. You need to resolve this manually 2025.04.02 01:46:39.607757 [ 3098 ] {68fe3a98-f7d4-4a2f-b500-76ae04346be8} test_d2f129d7.rmt1 (0419d31d-2ad6-481b-abd8-cf78ca931850): Part /var/lib/clickhouse/store/041/0419d31d-2ad6-481b-abd8-cf78ca931850/all_0_0_0/ is broken and needs manual correction. Reason: Code: 107. DB::Exception: store/041/0419d31d-2ad6-481b-abd8-cf78ca931850/all_0_0_0/data.bin doesn't exist: columns: columns format version: 1 2 columns: `a` Int32 `b` Int32 , getMarkSizeInBytes: 40, getMarksCount: 2, index_granularity_info: [mark_type: [adaptive: true, compressed: true, part_type: Compact], index_granularity_bytes: 10627972, fixed_index_granularity: 15428], index_granularity: [Constant(constant_granularity: 3, last_mark_granularity: 3, num_marks_without_final: 1, has_final_mark: true)], part_state: [state: Temporary, is_unexpected_local_part: false, is_frozen: false, is_duplicate: false]. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type>, std::__fs::filesystem::path&&) @ 0x000000003e0cd02a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartChecksum.cpp:73: DB::MergeTreeDataPartChecksum::checkSize(DB::IDataPartStorage const&, String const&) const @ 0x000000003e0d1b2d 5. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:2297: DB::IMergeTreeDataPart::checkConsistencyBase() const @ 0x000000003db7a551 6. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:2355: DB::IMergeTreeDataPart::checkConsistency(bool) const @ 0x000000003db4c0fe 7. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:844: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x000000003db3bdea 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1579: DB::MergeTreeData::loadDataPart(DB::MergeTreePartInfo const&, String const&, std::shared_ptr const&, DB::MergeTreeDataPartState, std::mutex&) @ 0x000000003de22de3 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1718: DB::MergeTreeData::loadDataPartWithRetries(DB::MergeTreePartInfo const&, String const&, std::shared_ptr const&, DB::MergeTreeDataPartState, std::mutex&, unsigned long, unsigned long, unsigned long) @ 0x000000003de3383c 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1780: void std::__function::__policy_invoker::__call_impl, std::allocator>>&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003e01391d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000027a374ac 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000027a3728d 13. ./contrib/llvm-project/libcxx/include/future:1876: std::packaged_task::operator()() @ 0x0000000027a39b9d 14. ./src/Common/threadPoolCallbackRunner.h:167: void std::__function::__policy_invoker::__call_impl>, std::function>::operator()(std::function&&, Priority)::'lambda0'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000027a39a0e 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002097cef4 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002098fd26 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002098fadf 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 20. ? @ 0x00007f583d9b1ac3 21. ? @ 0x00007f583da43850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:46:39.608464 [ 3098 ] {68fe3a98-f7d4-4a2f-b500-76ae04346be8} test_d2f129d7.rmt1 (0419d31d-2ad6-481b-abd8-cf78ca931850): while loading part all_0_0_0 on path store/041/0419d31d-2ad6-481b-abd8-cf78ca931850/all_0_0_0: Code: 107. DB::Exception: store/041/0419d31d-2ad6-481b-abd8-cf78ca931850/all_0_0_0/data.bin doesn't exist: columns: columns format version: 1 2 columns: `a` Int32 `b` Int32 , getMarkSizeInBytes: 40, getMarksCount: 2, index_granularity_info: [mark_type: [adaptive: true, compressed: true, part_type: Compact], index_granularity_bytes: 10627972, fixed_index_granularity: 15428], index_granularity: [Constant(constant_granularity: 3, last_mark_granularity: 3, num_marks_without_final: 1, has_final_mark: true)], part_state: [state: Temporary, is_unexpected_local_part: false, is_frozen: false, is_duplicate: false]: Part contains files: data.cmrk3 (58 bytes), primary.cidx (42 bytes), count.txt (1 bytes), serialization.json (145 bytes), checksums.txt (259 bytes), default_compression_codec.txt (10 bytes), columns.txt (57 bytes), metadata_version.txt (1 bytes). (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type>, std::__fs::filesystem::path&&) @ 0x000000003e0cd02a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartChecksum.cpp:73: DB::MergeTreeDataPartChecksum::checkSize(DB::IDataPartStorage const&, String const&) const @ 0x000000003e0d1b2d 5. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:2297: DB::IMergeTreeDataPart::checkConsistencyBase() const @ 0x000000003db7a551 6. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:2355: DB::IMergeTreeDataPart::checkConsistency(bool) const @ 0x000000003db4c0fe 7. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:844: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x000000003db3bdea 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1579: DB::MergeTreeData::loadDataPart(DB::MergeTreePartInfo const&, String const&, std::shared_ptr const&, DB::MergeTreeDataPartState, std::mutex&) @ 0x000000003de22de3 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1718: DB::MergeTreeData::loadDataPartWithRetries(DB::MergeTreePartInfo const&, String const&, std::shared_ptr const&, DB::MergeTreeDataPartState, std::mutex&, unsigned long, unsigned long, unsigned long) @ 0x000000003de3383c 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1780: void std::__function::__policy_invoker::__call_impl, std::allocator>>&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003e01391d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000027a374ac 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000027a3728d 13. ./contrib/llvm-project/libcxx/include/future:1876: std::packaged_task::operator()() @ 0x0000000027a39b9d 14. ./src/Common/threadPoolCallbackRunner.h:167: void std::__function::__policy_invoker::__call_impl>, std::function>::operator()(std::function&&, Priority)::'lambda0'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000027a39a0e 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002097cef4 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002098fd26 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002098fadf 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 20. ? @ 0x00007f583d9b1ac3 21. ? @ 0x00007f583da43850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:46:39.608813 [ 3098 ] {68fe3a98-f7d4-4a2f-b500-76ae04346be8} test_d2f129d7.rmt1 (0419d31d-2ad6-481b-abd8-cf78ca931850): Detaching broken part /var/lib/clickhouse/store/041/0419d31d-2ad6-481b-abd8-cf78ca931850/all_0_0_0 (size: 573.00 B). If it happened after update, it is likely because of backward incompatibility. You need to resolve this manually 2025.04.02 01:46:39.635018 [ 735 ] {} test_d2f129d7.rmt1 (0419d31d-2ad6-481b-abd8-cf78ca931850): Detached 0 parts covered by broken part all_0_0_0: 2025.04.02 01:46:39.641329 [ 735 ] {} test_d2f129d7.rmt1 (0419d31d-2ad6-481b-abd8-cf78ca931850): Detached 0 parts covered by broken part all_0_0_0_1: 2025.04.02 01:46:40.247272 [ 1432 ] {aa51b442-29bf-4c42-8b96-7c2ae4179bf2} executeQuery: Code: 36. DB::Exception: Dictionary (`invalid_dictionary`) not found: In scope WITH 'invalid_dictionary' AS dictionary SELECT dictGet(dictionary, 'value', toUInt64(0)). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:53080) (comment: 02384_analyzer_dict_get_join_get.sql) (in query: WITH 'invalid_dictionary' AS dictionary SELECT dictGet(dictionary, 'value', toUInt64(0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x0000000037686f9e 5. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:113: DB::ExternalDictionariesLoader::getDictionaryStructure(String const&, std::shared_ptr) const @ 0x0000000037688733 6. DB::FunctionDictHelper::getDictionaryStructure(String const&) const @ 0x0000000008e6e247 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008e5c2c7 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 27. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 28. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 2025.04.02 01:46:40.249257 [ 1432 ] {} TCPHandler: Code: 36. DB::Exception: Dictionary (`invalid_dictionary`) not found: In scope WITH 'invalid_dictionary' AS dictionary SELECT dictGet(dictionary, 'value', toUInt64(0)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x0000000037686f9e 5. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:113: DB::ExternalDictionariesLoader::getDictionaryStructure(String const&, std::shared_ptr) const @ 0x0000000037688733 6. DB::FunctionDictHelper::getDictionaryStructure(String const&) const @ 0x0000000008e6e247 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008e5c2c7 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 27. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 28. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 2025.04.02 01:46:40.302448 [ 3076 ] {0189b568-df6f-43d7-88be-33c4134dfaef} executeQuery: Code: 407. DB::Exception: Numeric overflow: While executing ConvertingAggregatedToChunksTransform. (DECIMAL_OVERFLOW) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:60694) (comment: 02029_quantile_sanitizer.sql) (in query: SELECT quantileTDigestWeighted(-0.)(toDateTime(10000000000.), 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./src/AggregateFunctions/QuantileTDigest.h:531: unsigned int DB::QuantileTDigest::getImpl(double) @ 0x000000002334e05c 5. ./src/AggregateFunctions/QuantileTDigest.h:506: DB::AggregateFunctionQuantile, DB::NameQuantileTDigestWeighted, true, void, false, false>::insertResultInto(char*, DB::IColumn&, DB::Arena*) const @ 0x00000000234cb728 6. ./build_docker/./src/Interpreters/Aggregator.cpp:1895: void DB::Aggregator::insertAggregatesIntoColumns(char*&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::Arena*) const @ 0x0000000036ca6690 7. ./build_docker/./src/Interpreters/Aggregator.cpp:2252: DB::Aggregator::prepareBlockAndFillWithoutKey(DB::AggregatedDataVariants&, bool, bool) const @ 0x0000000036a8621d 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:467: DB::ConvertingAggregatedToChunksTransform::initialize() @ 0x0000000040096347 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:299: DB::ConvertingAggregatedToChunksTransform::work() @ 0x000000004008c21e 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003f7213f8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002097cef4 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002098fd26 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002098fadf 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:46:40.306891 [ 3076 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: While executing ConvertingAggregatedToChunksTransform. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./src/AggregateFunctions/QuantileTDigest.h:531: unsigned int DB::QuantileTDigest::getImpl(double) @ 0x000000002334e05c 5. ./src/AggregateFunctions/QuantileTDigest.h:506: DB::AggregateFunctionQuantile, DB::NameQuantileTDigestWeighted, true, void, false, false>::insertResultInto(char*, DB::IColumn&, DB::Arena*) const @ 0x00000000234cb728 6. ./build_docker/./src/Interpreters/Aggregator.cpp:1895: void DB::Aggregator::insertAggregatesIntoColumns(char*&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::Arena*) const @ 0x0000000036ca6690 7. ./build_docker/./src/Interpreters/Aggregator.cpp:2252: DB::Aggregator::prepareBlockAndFillWithoutKey(DB::AggregatedDataVariants&, bool, bool) const @ 0x0000000036a8621d 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:467: DB::ConvertingAggregatedToChunksTransform::initialize() @ 0x0000000040096347 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:299: DB::ConvertingAggregatedToChunksTransform::work() @ 0x000000004008c21e 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003f7213f8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002097cef4 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002098fd26 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002098fadf 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:46:40.544088 [ 1429 ] {a3b9c256-7c28-4453-8d77-a276ccef64bd} executeQuery: Code: 264. DB::Exception: Table 'test_msq6q92o.testJoinTable (bf5e3b47-cd3b-42b1-8720-35cb29b442b8)' has incompatible type of JOIN. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:60710) (comment: 01050_engine_join_crash.sql) (in query: SELECT * FROM (SELECT * FROM numbers(10)) js1 INNER JOIN testJoinTable USING number;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Storages/StorageJoin.cpp:244: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x000000003ca50324 5. ./build_docker/./src/Planner/PlannerJoins.cpp:905: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x000000003873d11e 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1690: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000386e5233 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000386b9598 8. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000003865cf3b 9. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 20. ? @ 0x00007f583d9b1ac3 21. ? @ 0x00007f583da43850 2025.04.02 01:46:40.546822 [ 1429 ] {} TCPHandler: Code: 264. DB::Exception: Table 'test_msq6q92o.testJoinTable (bf5e3b47-cd3b-42b1-8720-35cb29b442b8)' has incompatible type of JOIN. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Storages/StorageJoin.cpp:244: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x000000003ca50324 5. ./build_docker/./src/Planner/PlannerJoins.cpp:905: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x000000003873d11e 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1690: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000386e5233 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000386b9598 8. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000003865cf3b 9. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 20. ? @ 0x00007f583d9b1ac3 21. ? @ 0x00007f583da43850 2025.04.02 01:46:41.262126 [ 1432 ] {58999e23-f801-40d2-9f7d-0609be3b2e3a} executeQuery: Code: 60. DB::Exception: Table test_s214q9n8.invalid_test_table_join does not exist: In scope WITH 'invalid_test_table_join' AS join_table SELECT joinGet(join_table, 'value', toUInt64(0)). (UNKNOWN_TABLE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:53080) (comment: 02384_analyzer_dict_get_join_get.sql) (in query: WITH 'invalid_test_table_join' AS join_table SELECT joinGet(join_table, 'value', toUInt64(0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000035344908 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:441: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000368893f5 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:970: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000003689e2e6 7. DB::(anonymous namespace)::getJoin(std::vector> const&, std::shared_ptr) @ 0x00000000089159dd 8. DB::(anonymous namespace)::JoinGetOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x0000000008910e74 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c0157f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:46:41.265199 [ 1432 ] {} TCPHandler: Code: 60. DB::Exception: Table test_s214q9n8.invalid_test_table_join does not exist: In scope WITH 'invalid_test_table_join' AS join_table SELECT joinGet(join_table, 'value', toUInt64(0)). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000035344908 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:441: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000368893f5 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:970: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000003689e2e6 7. DB::(anonymous namespace)::getJoin(std::vector> const&, std::shared_ptr) @ 0x00000000089159dd 8. DB::(anonymous namespace)::JoinGetOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x0000000008910e74 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c0157f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:46:42.520292 [ 1432 ] {67215a47-9da2-471d-92fe-30e53aca421b} executeQuery: Code: 60. DB::Exception: Temporary table table_to_drop doesn't exist. (UNKNOWN_TABLE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:60772) (comment: 01072_drop_temporary_table_with_same_name.sql) (in query: DROP TEMPORARY TABLE table_to_drop;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:143: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003783f9a7 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:122: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000037838f5f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000037835cb9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:76: DB::InterpreterDropQuery::execute() @ 0x0000000037835513 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 10. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 11. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 17. ? @ 0x00007f583d9b1ac3 18. ? @ 0x00007f583da43850 2025.04.02 01:46:42.522436 [ 1432 ] {} TCPHandler: Code: 60. DB::Exception: Temporary table table_to_drop doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:143: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003783f9a7 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:122: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000037838f5f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000037835cb9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:76: DB::InterpreterDropQuery::execute() @ 0x0000000037835513 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 10. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 11. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 17. ? @ 0x00007f583d9b1ac3 18. ? @ 0x00007f583da43850 2025.04.02 01:46:42.976562 [ 1432 ] {16381e1c-133c-4026-ac96-17fff10706cc} executeQuery: Code: 60. DB::Exception: Table test_3dv6ojp9.table_to_drop does not exist. (UNKNOWN_TABLE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:60772) (comment: 01072_drop_temporary_table_with_same_name.sql) (in query: DROP TABLE table_to_drop;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000035344908 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:441: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000368893f5 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000003689e934 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:150: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003783b0ab 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:122: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000037838f5f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000037835cb9 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:76: DB::InterpreterDropQuery::execute() @ 0x0000000037835513 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 20. ? @ 0x00007f583d9b1ac3 21. ? @ 0x00007f583da43850 2025.04.02 01:46:42.978411 [ 1432 ] {} TCPHandler: Code: 60. DB::Exception: Table test_3dv6ojp9.table_to_drop does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000035344908 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:441: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000368893f5 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000003689e934 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:150: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003783b0ab 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:122: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000037838f5f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000037835cb9 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:76: DB::InterpreterDropQuery::execute() @ 0x0000000037835513 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 20. ? @ 0x00007f583d9b1ac3 21. ? @ 0x00007f583da43850 2025.04.02 01:46:43.044908 [ 1432 ] {b386a5a2-35a4-4034-abce-07b84d2e4e6b} executeQuery: Code: 60. DB::Exception: Table test_3dv6ojp9.table_to_drop does not exist. (UNKNOWN_TABLE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:60772) (comment: 01072_drop_temporary_table_with_same_name.sql) (in query: DROP TABLE table_to_drop;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000035344908 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:441: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000368893f5 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000003689e934 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:150: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003783b0ab 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:122: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000037838f5f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000037835cb9 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:76: DB::InterpreterDropQuery::execute() @ 0x0000000037835513 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 20. ? @ 0x00007f583d9b1ac3 21. ? @ 0x00007f583da43850 2025.04.02 01:46:43.046602 [ 1432 ] {} TCPHandler: Code: 60. DB::Exception: Table test_3dv6ojp9.table_to_drop does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000035344908 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:441: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000368893f5 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000003689e934 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:150: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003783b0ab 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:122: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000037838f5f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000037835cb9 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:76: DB::InterpreterDropQuery::execute() @ 0x0000000037835513 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 20. ? @ 0x00007f583d9b1ac3 21. ? @ 0x00007f583da43850 2025.04.02 01:46:43.086835 [ 3161 ] {df3351b7-4cbe-41c9-b561-015c224560dd} executeQuery: Code: 290. DB::Exception: Limit would be exceeded by inserting 2 new key(s). Limit is 3, while the number of keys would be 4. (LIMIT_EXCEEDED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:60756) (comment: 02418_keeper_map_keys_limit.sql) (in query: INSERT INTO 02418_test VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x00000000396ab0b7 4. ./build_docker/./src/Storages/StorageKeeperMap.cpp:257: void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()::operator()() const @ 0x000000003cb9a9b6 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&)::'lambda'()&&) @ 0x000000003cb9755f 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: void DB::StorageKeeperMapSink::finalize(bool) @ 0x000000003cb970fd 7. ./build_docker/./src/Storages/StorageKeeperMap.cpp:179: DB::StorageKeeperMapSink::onFinish() @ 0x000000003cb940f9 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x00000000400e20ef 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000400e0ff6 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x00000000400dfee2 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 14. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003f76f0ba 15. ./build_docker/./src/Server/TCPHandler.cpp:1122: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003f44ec83 16. ./build_docker/./src/Server/TCPHandler.cpp:665: DB::TCPHandler::runImpl() @ 0x000000003f42c409 17. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 23. ? @ 0x00007f583d9b1ac3 24. ? @ 0x00007f583da43850 2025.04.02 01:46:43.089237 [ 3161 ] {} TCPHandler: Code: 290. DB::Exception: Limit would be exceeded by inserting 2 new key(s). Limit is 3, while the number of keys would be 4. (LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x00000000396ab0b7 4. ./build_docker/./src/Storages/StorageKeeperMap.cpp:257: void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()::operator()() const @ 0x000000003cb9a9b6 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&)::'lambda'()&&) @ 0x000000003cb9755f 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: void DB::StorageKeeperMapSink::finalize(bool) @ 0x000000003cb970fd 7. ./build_docker/./src/Storages/StorageKeeperMap.cpp:179: DB::StorageKeeperMapSink::onFinish() @ 0x000000003cb940f9 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x00000000400e20ef 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000400e0ff6 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x00000000400dfee2 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 14. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003f76f0ba 15. ./build_docker/./src/Server/TCPHandler.cpp:1122: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003f44ec83 16. ./build_docker/./src/Server/TCPHandler.cpp:665: DB::TCPHandler::runImpl() @ 0x000000003f42c409 17. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 23. ? @ 0x00007f583d9b1ac3 24. ? @ 0x00007f583da43850 2025.04.02 01:46:43.178200 [ 3161 ] {7b753ece-e37b-4fed-956e-8df39248263b} executeQuery: Code: 290. DB::Exception: Limit would be exceeded by inserting 1 new key(s). Limit is 3, while the number of keys would be 4. (LIMIT_EXCEEDED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:60756) (comment: 02418_keeper_map_keys_limit.sql) (in query: INSERT INTO 02418_test VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x00000000396ab0b7 4. ./build_docker/./src/Storages/StorageKeeperMap.cpp:257: void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()::operator()() const @ 0x000000003cb9a9b6 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&)::'lambda'()&&) @ 0x000000003cb9755f 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: void DB::StorageKeeperMapSink::finalize(bool) @ 0x000000003cb970fd 7. ./build_docker/./src/Storages/StorageKeeperMap.cpp:179: DB::StorageKeeperMapSink::onFinish() @ 0x000000003cb940f9 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x00000000400e20ef 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000400e0ff6 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x00000000400dfee2 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 14. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003f76f0ba 15. ./build_docker/./src/Server/TCPHandler.cpp:1122: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003f44ec83 16. ./build_docker/./src/Server/TCPHandler.cpp:665: DB::TCPHandler::runImpl() @ 0x000000003f42c409 17. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 23. ? @ 0x00007f583d9b1ac3 24. ? @ 0x00007f583da43850 2025.04.02 01:46:43.180712 [ 3161 ] {} TCPHandler: Code: 290. DB::Exception: Limit would be exceeded by inserting 1 new key(s). Limit is 3, while the number of keys would be 4. (LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x00000000396ab0b7 4. ./build_docker/./src/Storages/StorageKeeperMap.cpp:257: void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()::operator()() const @ 0x000000003cb9a9b6 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&)::'lambda'()&&) @ 0x000000003cb9755f 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: void DB::StorageKeeperMapSink::finalize(bool) @ 0x000000003cb970fd 7. ./build_docker/./src/Storages/StorageKeeperMap.cpp:179: DB::StorageKeeperMapSink::onFinish() @ 0x000000003cb940f9 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x00000000400e20ef 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000400e0ff6 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x00000000400dfee2 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 14. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003f76f0ba 15. ./build_docker/./src/Server/TCPHandler.cpp:1122: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003f44ec83 16. ./build_docker/./src/Server/TCPHandler.cpp:665: DB::TCPHandler::runImpl() @ 0x000000003f42c409 17. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 23. ? @ 0x00007f583d9b1ac3 24. ? @ 0x00007f583da43850 2025.04.02 01:46:43.353463 [ 3161 ] {cae1459a-843c-47b0-9ac5-9f55ce6fa417} executeQuery: Code: 290. DB::Exception: Limit would be exceeded by inserting 1 new key(s). Limit is 3, while the number of keys would be 4. (LIMIT_EXCEEDED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:60756) (comment: 02418_keeper_map_keys_limit.sql) (in query: INSERT INTO 02418_test VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x00000000396ab0b7 4. ./build_docker/./src/Storages/StorageKeeperMap.cpp:257: void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()::operator()() const @ 0x000000003cb9a9b6 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&)::'lambda'()&&) @ 0x000000003cb9755f 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: void DB::StorageKeeperMapSink::finalize(bool) @ 0x000000003cb970fd 7. ./build_docker/./src/Storages/StorageKeeperMap.cpp:179: DB::StorageKeeperMapSink::onFinish() @ 0x000000003cb940f9 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x00000000400e20ef 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000400e0ff6 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x00000000400dfee2 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 14. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003f76f0ba 15. ./build_docker/./src/Server/TCPHandler.cpp:1122: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003f44ec83 16. ./build_docker/./src/Server/TCPHandler.cpp:665: DB::TCPHandler::runImpl() @ 0x000000003f42c409 17. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 23. ? @ 0x00007f583d9b1ac3 24. ? @ 0x00007f583da43850 2025.04.02 01:46:43.356060 [ 3161 ] {} TCPHandler: Code: 290. DB::Exception: Limit would be exceeded by inserting 1 new key(s). Limit is 3, while the number of keys would be 4. (LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x00000000396ab0b7 4. ./build_docker/./src/Storages/StorageKeeperMap.cpp:257: void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()::operator()() const @ 0x000000003cb9a9b6 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&)::'lambda'()&&) @ 0x000000003cb9755f 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: void DB::StorageKeeperMapSink::finalize(bool) @ 0x000000003cb970fd 7. ./build_docker/./src/Storages/StorageKeeperMap.cpp:179: DB::StorageKeeperMapSink::onFinish() @ 0x000000003cb940f9 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x00000000400e20ef 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000400e0ff6 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x00000000400dfee2 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 14. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003f76f0ba 15. ./build_docker/./src/Server/TCPHandler.cpp:1122: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003f44ec83 16. ./build_docker/./src/Server/TCPHandler.cpp:665: DB::TCPHandler::runImpl() @ 0x000000003f42c409 17. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 23. ? @ 0x00007f583d9b1ac3 24. ? @ 0x00007f583da43850 2025.04.02 01:46:44.734382 [ 3076 ] {81004515-1add-4e83-9cca-ead3409d7458} executeQuery: Code: 387. DB::Exception: Dictionary test_g3r6kxgv.test_dict already exists. (DICTIONARY_ALREADY_EXISTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:60854) (comment: 02973_dictionary_table_exception_fix.sql) (in query: CREATE TABLE test_dict (`y` Int64) ENGINE = MergeTree ORDER BY y SETTINGS index_granularity = 15215, min_bytes_for_wide_part = 137882035, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 32, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 410809433, compact_parts_max_granules_to_buffer = 206, compact_parts_merge_max_bytes_to_prefetch_part = 22425400, merge_max_block_size = 23933, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8529893495, index_granularity_bytes = 24092715, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 36, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 38696, primary_key_compress_block_size = 66812, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377e4b4d 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:46:44.736585 [ 3076 ] {} TCPHandler: Code: 387. DB::Exception: Dictionary test_g3r6kxgv.test_dict already exists. (DICTIONARY_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377e4b4d 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:46:45.172492 [ 3076 ] {e50e5254-17f7-40d4-ab7a-ae51aebd7e7c} executeQuery: Code: 57. DB::Exception: Table test_g3r6kxgv.test_table already exists. (TABLE_ALREADY_EXISTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:60854) (comment: 02973_dictionary_table_exception_fix.sql) (in query: CREATE DICTIONARY test_table (y String, value UInt64 DEFAULT 0) PRIMARY KEY y SOURCE(CLICKHOUSE(TABLE 'test_table')) LAYOUT(DIRECT());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1829: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377eb9d2 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:46:45.174707 [ 3076 ] {} TCPHandler: Code: 57. DB::Exception: Table test_g3r6kxgv.test_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1829: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377eb9d2 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:46:45.183202 [ 3076 ] {d2ef12db-b7b8-4f37-aaeb-7a2f4c975301} executeQuery: Code: 387. DB::Exception: Dictionary test_g3r6kxgv.test_dict already exists. (DICTIONARY_ALREADY_EXISTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:60854) (comment: 02973_dictionary_table_exception_fix.sql) (in query: CREATE DICTIONARY test_dict (y String, value UInt64 DEFAULT 0) PRIMARY KEY y SOURCE(CLICKHOUSE(TABLE 'test_table')) LAYOUT(DIRECT());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377e4b4d 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:46:45.184980 [ 3076 ] {} TCPHandler: Code: 387. DB::Exception: Dictionary test_g3r6kxgv.test_dict already exists. (DICTIONARY_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377e4b4d 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:46:45.198337 [ 3076 ] {aa2aeb18-4ad3-4eb7-bdfb-d738fe9e912c} executeQuery: Code: 57. DB::Exception: Table test_g3r6kxgv.test_table already exists. (TABLE_ALREADY_EXISTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:60854) (comment: 02973_dictionary_table_exception_fix.sql) (in query: CREATE TABLE test_table (`y` Int64) ENGINE = MergeTree ORDER BY y SETTINGS index_granularity = 15215, min_bytes_for_wide_part = 137882035, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 32, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 410809433, compact_parts_max_granules_to_buffer = 206, compact_parts_merge_max_bytes_to_prefetch_part = 22425400, merge_max_block_size = 23933, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8529893495, index_granularity_bytes = 24092715, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 36, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 38696, primary_key_compress_block_size = 66812, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1829: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377eb9d2 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:46:45.200228 [ 3076 ] {} TCPHandler: Code: 57. DB::Exception: Table test_g3r6kxgv.test_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1829: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377eb9d2 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:46:45.683681 [ 2377 ] {4ac24101-badc-4e62-8734-a27145b250f7} executeQuery: Code: 36. DB::Exception: StorageEmbeddedRocksDB must require one column in primary key. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:60890) (comment: 01504_rocksdb.sql) (in query: CREATE TABLE 01504_test (key String, value UInt32) Engine=EmbeddedRocksDB;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Storages/RocksDB/StorageEmbeddedRocksDB.cpp:709: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000335017c3 5. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000033526b3a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003c9464fa 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377e8869 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 12. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 19. ? @ 0x00007f583d9b1ac3 20. ? @ 0x00007f583da43850 2025.04.02 01:46:45.686018 [ 2377 ] {} TCPHandler: Code: 36. DB::Exception: StorageEmbeddedRocksDB must require one column in primary key. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Storages/RocksDB/StorageEmbeddedRocksDB.cpp:709: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000335017c3 5. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000033526b3a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003c9464fa 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377e8869 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 12. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 19. ? @ 0x00007f583d9b1ac3 20. ? @ 0x00007f583da43850 2025.04.02 01:46:46.244909 [ 2377 ] {85540eb0-3905-4373-bdb5-fa8b5851bc08} executeQuery: Code: 47. DB::Exception: Missing columns: 'key2' while processing query: 'key2', required columns: 'key2' 'key2'. (UNKNOWN_IDENTIFIER) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:60890) (comment: 01504_rocksdb.sql) (in query: CREATE TABLE 01504_test (key String, value UInt32) Engine=EmbeddedRocksDB PRIMARY KEY(key2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1305: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000039027225 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1563: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003904a642 5. ./build_docker/./src/Storages/KeyDescription.cpp:162: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003c7e3839 6. ./build_docker/./src/Storages/KeyDescription.cpp:92: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003c7e6d5f 7. ./build_docker/./src/Storages/RocksDB/StorageEmbeddedRocksDB.cpp:711: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000335004c8 8. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000033526b3a 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003c9464fa 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377e8869 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:46:46.246768 [ 2377 ] {} TCPHandler: Code: 47. DB::Exception: Missing columns: 'key2' while processing query: 'key2', required columns: 'key2' 'key2'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1305: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000039027225 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1563: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003904a642 5. ./build_docker/./src/Storages/KeyDescription.cpp:162: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003c7e3839 6. ./build_docker/./src/Storages/KeyDescription.cpp:92: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003c7e6d5f 7. ./build_docker/./src/Storages/RocksDB/StorageEmbeddedRocksDB.cpp:711: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000335004c8 8. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000033526b3a 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003c9464fa 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377e8869 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:46:46.764155 [ 2377 ] {c514bd18-11d7-4133-96da-ccb666635513} executeQuery: Code: 36. DB::Exception: StorageEmbeddedRocksDB must require one column in primary key. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:60890) (comment: 01504_rocksdb.sql) (in query: CREATE TABLE 01504_test (key String, value UInt32) Engine=EmbeddedRocksDB PRIMARY KEY(key, value);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Storages/RocksDB/StorageEmbeddedRocksDB.cpp:715: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000033501959 5. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000033526b3a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003c9464fa 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377e8869 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 12. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 19. ? @ 0x00007f583d9b1ac3 20. ? @ 0x00007f583da43850 2025.04.02 01:46:46.766205 [ 2377 ] {} TCPHandler: Code: 36. DB::Exception: StorageEmbeddedRocksDB must require one column in primary key. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Storages/RocksDB/StorageEmbeddedRocksDB.cpp:715: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000033501959 5. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000033526b3a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003c9464fa 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377e8869 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 12. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 19. ? @ 0x00007f583d9b1ac3 20. ? @ 0x00007f583da43850 2025.04.02 01:46:48.896357 [ 1372 ] {a24c759f-227a-4e74-89dc-2635c1bb1f67} executeQuery: Code: 59. DB::Exception: Invalid type for filter in WHERE: Array(Nullable(String)). In query WITH CAST(tuple(1), 'Tuple (value UInt64)') AS compound_value SELECT id, test_table.* APPLY (x -> compound_value.*) FROM test_table WHERE arrayMap(x -> toString(x) AS lambda, [NULL, 256, 257, NULL, NULL]) SETTINGS convert_query_to_cnf = true, optimize_using_constraints = true, optimize_substitute_columns = true. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:60918) (comment: 03144_invalid_filter.sql) (in query: WITH CAST(tuple(1), 'Tuple (value UInt64)') AS compound_value SELECT id, test_table.* APPLY x -> compound_value.* FROM test_table WHERE arrayMap(x -> toString(x) AS lambda, [NULL, 256, 257, NULL, NULL]) SETTINGS convert_query_to_cnf = true, optimize_using_constraints = true, optimize_substitute_columns = true;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x0000000034387ff7 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x0000000035e87016 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:74: DB::validateFilters(std::shared_ptr const&) @ 0x0000000035e86343 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5734: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d2906b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 17. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 18. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 24. ? @ 0x00007f583d9b1ac3 25. ? @ 0x00007f583da43850 2025.04.02 01:46:48.899431 [ 1372 ] {} TCPHandler: Code: 59. DB::Exception: Invalid type for filter in WHERE: Array(Nullable(String)). In query WITH CAST(tuple(1), 'Tuple (value UInt64)') AS compound_value SELECT id, test_table.* APPLY (x -> compound_value.*) FROM test_table WHERE arrayMap(x -> toString(x) AS lambda, [NULL, 256, 257, NULL, NULL]) SETTINGS convert_query_to_cnf = true, optimize_using_constraints = true, optimize_substitute_columns = true. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x0000000034387ff7 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x0000000035e87016 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:74: DB::validateFilters(std::shared_ptr const&) @ 0x0000000035e86343 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5734: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d2906b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 17. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 18. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 24. ? @ 0x00007f583d9b1ac3 25. ? @ 0x00007f583da43850 2025.04.02 01:46:49.375530 [ 1372 ] {d930aa46-def7-4633-a0cb-8196f3b6857a} executeQuery: Code: 59. DB::Exception: Invalid type for filter in WHERE: String. In query SELECT test_table.COLUMNS(id) FROM test_table WHERE '2147483647'. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:60918) (comment: 03144_invalid_filter.sql) (in query: DESCRIBE TABLE (SELECT test_table.COLUMNS(id) FROM test_table WHERE '2147483647');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x0000000034387ff7 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x0000000035e87016 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:74: DB::validateFilters(std::shared_ptr const&) @ 0x0000000035e86343 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5734: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d2906b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 12. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:143: DB::InterpreterDescribeQuery::fillColumnsFromSubquery(DB::ASTTableExpression const&) @ 0x00000000393bc373 13. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:100: DB::InterpreterDescribeQuery::execute() @ 0x00000000393ba6de 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 16. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 17. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 23. ? @ 0x00007f583d9b1ac3 24. ? @ 0x00007f583da43850 2025.04.02 01:46:49.378492 [ 1372 ] {} TCPHandler: Code: 59. DB::Exception: Invalid type for filter in WHERE: String. In query SELECT test_table.COLUMNS(id) FROM test_table WHERE '2147483647'. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x0000000034387ff7 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x0000000035e87016 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:74: DB::validateFilters(std::shared_ptr const&) @ 0x0000000035e86343 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5734: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d2906b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 12. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:143: DB::InterpreterDescribeQuery::fillColumnsFromSubquery(DB::ASTTableExpression const&) @ 0x00000000393bc373 13. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:100: DB::InterpreterDescribeQuery::execute() @ 0x00000000393ba6de 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 16. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 17. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 23. ? @ 0x00007f583d9b1ac3 24. ? @ 0x00007f583da43850 2025.04.02 01:46:56.326603 [ 1755 ] {6d26982f-3b40-466b-9307-8050b0b55fed} MergeTreeDataWriter: Incorrect data: number of rows with sign = 1 (9000) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 0).). 2025.04.02 01:46:57.510503 [ 3300 ] {031a88f3-6a90-457d-9d98-427991e6ecb2} executeQuery: Code: 57. DB::Exception: Table system.columns already exists. (TABLE_ALREADY_EXISTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:46344) (comment: 01445_create_table_as_table_function.sh) (in query: CREATE TABLE system.columns AS numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1829: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377eb9d2 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:46:57.530951 [ 3300 ] {} TCPHandler: Code: 57. DB::Exception: Table system.columns already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1829: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377eb9d2 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:46:59.179075 [ 423 ] {4c06e1de-d59e-4c62-a4aa-71aaaece704a} executeQuery: Code: 344. DB::Exception: ALTER TABLE commands are not supported on immutable disk 'cont-03008-azure-plain-rewritable-with-slash-test-54l9cijd', except for setting and comment alteration. (SUPPORT_IS_DISABLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:46352) (comment: 03008_azure_plain_rewritable_with_slash.sh) (in query: alter table test_azure_mt add projection test_azure_mt_projection (select * order by b)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ac716ea 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3495: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003deb1cc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:218: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775be7b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:46:59.192293 [ 423 ] {} TCPHandler: Code: 344. DB::Exception: ALTER TABLE commands are not supported on immutable disk 'cont-03008-azure-plain-rewritable-with-slash-test-54l9cijd', except for setting and comment alteration. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ac716ea 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3495: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003deb1cc4 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:218: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775be7b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:47:00.488148 [ 1372 ] {fa33f897-d887-4996-9819-26bd68f9eb1d} executeQuery: Code: 344. DB::Exception: Mutations are not supported for immutable disk 'cont-03008-azure-plain-rewritable-with-slash-test-54l9cijd'. (SUPPORT_IS_DISABLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44878) (comment: 03008_azure_plain_rewritable_with_slash.sh) (in query: alter table test_azure_mt update c = 0 where a % 2 = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ac716ea 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3900: DB::MergeTreeData::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000003dec95c6 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775c3b7 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:47:00.492026 [ 1372 ] {} TCPHandler: Code: 344. DB::Exception: Mutations are not supported for immutable disk 'cont-03008-azure-plain-rewritable-with-slash-test-54l9cijd'. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ac716ea 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3900: DB::MergeTreeData::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000003dec95c6 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775c3b7 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:47:03.201875 [ 1372 ] {b1f9886d-5b26-44b7-a1cf-ba7f2d3fcf27} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 1. Bytes expected: 15.: In scope SELECT finalizeAggregation(CAST(unhex('0F00000030'), 'AggregateFunction(min, String)')). (CANNOT_READ_ALL_DATA) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44894) (comment: 02477_invalid_reads.sql) (in query: -- MIN, MAX AND FAMILY should check for errors in its input SELECT finalizeAggregation(CAST(unhex('0F00000030'), 'AggregateFunction(min, String)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1143: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x0000000023d00922 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:135: DB::(anonymous namespace)::AggregateFunctionMinMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000023caad6f 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 2025.04.02 01:47:03.205131 [ 1372 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 1. Bytes expected: 15.: In scope SELECT finalizeAggregation(CAST(unhex('0F00000030'), 'AggregateFunction(min, String)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1143: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x0000000023d00922 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:135: DB::(anonymous namespace)::AggregateFunctionMinMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000023caad6f 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 2025.04.02 01:47:04.066607 [ 1372 ] {82e368c5-c238-4b24-8aca-b69e383279f9} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 1. Bytes expected: 65535.: In scope SELECT finalizeAggregation(CAST(unhex('FFFF000030'), 'AggregateFunction(min, String)')). (CANNOT_READ_ALL_DATA) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44894) (comment: 02477_invalid_reads.sql) (in query: SELECT finalizeAggregation(CAST(unhex('FFFF000030'), 'AggregateFunction(min, String)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1150: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x0000000023d0099d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:135: DB::(anonymous namespace)::AggregateFunctionMinMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000023caad6f 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 2025.04.02 01:47:04.070032 [ 1372 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 1. Bytes expected: 65535.: In scope SELECT finalizeAggregation(CAST(unhex('FFFF000030'), 'AggregateFunction(min, String)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1150: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x0000000023d0099d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:135: DB::(anonymous namespace)::AggregateFunctionMinMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000023caad6f 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 2025.04.02 01:47:05.177286 [ 1372 ] {53a36ac7-c3a8-42d1-b402-61c89446690b} executeQuery: Code: 32. DB::Exception: Attempt to read after eof: In scope SELECT finalizeAggregation(CAST('', 'AggregateFunction(aggThrow(0.), UInt8)')). (ATTEMPT_TO_READ_AFTER_EOF) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44894) (comment: 02477_invalid_reads.sql) (in query: -- aggThrow should check for errors in its input SELECT finalizeAggregation(CAST('', 'AggregateFunction(aggThrow(0.), UInt8)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. DB::ReadBuffer::throwReadAfterEOF() @ 0x000000000ac8b2ac 5. ./src/IO/ReadBuffer.h:172: DB::(anonymous namespace)::AggregateFunctionThrow::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000026a6f701 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 2025.04.02 01:47:05.181469 [ 1372 ] {} TCPHandler: Code: 32. DB::Exception: Attempt to read after eof: In scope SELECT finalizeAggregation(CAST('', 'AggregateFunction(aggThrow(0.), UInt8)')). (ATTEMPT_TO_READ_AFTER_EOF), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. DB::ReadBuffer::throwReadAfterEOF() @ 0x000000000ac8b2ac 5. ./src/IO/ReadBuffer.h:172: DB::(anonymous namespace)::AggregateFunctionThrow::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000026a6f701 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 2025.04.02 01:47:06.010930 [ 1372 ] {58d17e17-db13-4663-b8cf-ac2879054f39} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 16. Bytes expected: 32.: In scope SELECT finalizeAggregation(CAST(unhex('01000000000000000100000000000000'), 'AggregateFunction(categoricalInformationValue, UInt8, UInt8)')). (CANNOT_READ_ALL_DATA) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44894) (comment: 02477_invalid_reads.sql) (in query: -- categoricalInformationValue should check for errors in its input SELECT finalizeAggregation(CAST(unhex('01000000000000000100000000000000'), 'AggregateFunction(categoricalInformationValue, UInt8, UInt8)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:121: DB::AggregateFunctionCategoricalIV::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000026a62035 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 2025.04.02 01:47:06.015022 [ 1372 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 16. Bytes expected: 32.: In scope SELECT finalizeAggregation(CAST(unhex('01000000000000000100000000000000'), 'AggregateFunction(categoricalInformationValue, UInt8, UInt8)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:121: DB::AggregateFunctionCategoricalIV::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000026a62035 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 2025.04.02 01:47:07.035306 [ 1372 ] {efbba103-5164-4964-82b9-4590fdc12045} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 31. Bytes expected: 32.: In scope SELECT finalizeAggregation(CAST(unhex('0101000000000000000100000000000000020000000000000001000000000000'), 'AggregateFunction(categoricalInformationValue, Nullable(UInt8), UInt8)')). (CANNOT_READ_ALL_DATA) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44894) (comment: 02477_invalid_reads.sql) (in query: SELECT finalizeAggregation(CAST(unhex('0101000000000000000100000000000000020000000000000001000000000000'), 'AggregateFunction(categoricalInformationValue, Nullable(UInt8), UInt8)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:121: DB::AggregateFunctionCategoricalIV::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000026a62035 6. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:188: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000273421aa 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 2025.04.02 01:47:07.040012 [ 1372 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 31. Bytes expected: 32.: In scope SELECT finalizeAggregation(CAST(unhex('0101000000000000000100000000000000020000000000000001000000000000'), 'AggregateFunction(categoricalInformationValue, Nullable(UInt8), UInt8)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:121: DB::AggregateFunctionCategoricalIV::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000026a62035 6. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:188: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000273421aa 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 2025.04.02 01:47:08.115609 [ 1372 ] {e29ae526-bab5-4a2f-9887-c0bf0f8091ca} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 4. Bytes expected: 6271.: In scope SELECT finalizeAggregation(CAST(unhex('5FF3001310132'), 'AggregateFunction(groupArray, String)')). (CANNOT_READ_ALL_DATA) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44894) (comment: 02477_invalid_reads.sql) (in query: -- groupArray should check for errors in its input SELECT finalizeAggregation(CAST(unhex('5FF3001310132'), 'AggregateFunction(groupArray, String)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:425: DB::(anonymous namespace)::GroupArrayNodeBase::read(DB::ReadBuffer&, DB::Arena*) @ 0x0000000021a6399f 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:689: DB::(anonymous namespace)::GroupArrayGeneralImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000021af6557 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 2025.04.02 01:47:08.118673 [ 1372 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 4. Bytes expected: 6271.: In scope SELECT finalizeAggregation(CAST(unhex('5FF3001310132'), 'AggregateFunction(groupArray, String)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:425: DB::(anonymous namespace)::GroupArrayNodeBase::read(DB::ReadBuffer&, DB::Arena*) @ 0x0000000021a6399f 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:689: DB::(anonymous namespace)::GroupArrayGeneralImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000021af6557 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 2025.04.02 01:47:09.042142 [ 1372 ] {b204e2ab-a8b0-4ade-b268-ec87974b3f05} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 23. Bytes expected: 1016.: In scope SELECT finalizeAggregation(CAST(unhex('FF000000000000000001000000000000000200000000000000'), 'AggregateFunction(groupArray, UInt64)')). (CANNOT_READ_ALL_DATA) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44894) (comment: 02477_invalid_reads.sql) (in query: SELECT finalizeAggregation(CAST(unhex('FF000000000000000001000000000000000200000000000000'), 'AggregateFunction(groupArray, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:337: DB::(anonymous namespace)::GroupArrayNumericImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000021a99366 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 2025.04.02 01:47:09.050335 [ 1372 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 23. Bytes expected: 1016.: In scope SELECT finalizeAggregation(CAST(unhex('FF000000000000000001000000000000000200000000000000'), 'AggregateFunction(groupArray, UInt64)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:337: DB::(anonymous namespace)::GroupArrayNumericImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000021a99366 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 2025.04.02 01:47:10.092948 [ 1372 ] {4fb24e44-8811-4744-b41e-f56b0fa8727d} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 24. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0FF00000000000000001000000000000000300000000000000'), 'AggregateFunction(groupArrayMovingSum, UInt64)')). (CANNOT_READ_ALL_DATA) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44894) (comment: 02477_invalid_reads.sql) (in query: -- Same for groupArrayMovingXXXX SELECT finalizeAggregation(CAST(unhex('0FF00000000000000001000000000000000300000000000000'), 'AggregateFunction(groupArrayMovingSum, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:157: DB::MovingImpl, DB::MovingSumData>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000267a3c1c 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 2025.04.02 01:47:10.095660 [ 1372 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 24. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0FF00000000000000001000000000000000300000000000000'), 'AggregateFunction(groupArrayMovingSum, UInt64)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:157: DB::MovingImpl, DB::MovingSumData>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000267a3c1c 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 2025.04.02 01:47:11.059386 [ 423 ] {2ddc00f8-dd85-4378-ae84-d4742cdda07e::19700101_19700101_1_3_1} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 0).). 2025.04.02 01:47:11.095601 [ 423 ] {2ddc00f8-dd85-4378-ae84-d4742cdda07e::19700101_19700101_1_3_1} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 9000).). 2025.04.02 01:47:11.095738 [ 423 ] {2ddc00f8-dd85-4378-ae84-d4742cdda07e::19700101_19700101_1_3_1} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 9001).). 2025.04.02 01:47:11.095840 [ 423 ] {2ddc00f8-dd85-4378-ae84-d4742cdda07e::19700101_19700101_1_3_1} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 9002).). 2025.04.02 01:47:11.096298 [ 423 ] {2ddc00f8-dd85-4378-ae84-d4742cdda07e::19700101_19700101_1_3_1} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 9003).). 2025.04.02 01:47:11.096388 [ 423 ] {2ddc00f8-dd85-4378-ae84-d4742cdda07e::19700101_19700101_1_3_1} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 9004).). 2025.04.02 01:47:11.096462 [ 423 ] {2ddc00f8-dd85-4378-ae84-d4742cdda07e::19700101_19700101_1_3_1} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 9005).). 2025.04.02 01:47:11.096536 [ 423 ] {2ddc00f8-dd85-4378-ae84-d4742cdda07e::19700101_19700101_1_3_1} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 9006).). 2025.04.02 01:47:11.096618 [ 423 ] {2ddc00f8-dd85-4378-ae84-d4742cdda07e::19700101_19700101_1_3_1} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 9007).). 2025.04.02 01:47:11.096706 [ 423 ] {2ddc00f8-dd85-4378-ae84-d4742cdda07e::19700101_19700101_1_3_1} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 0, 9008).). 2025.04.02 01:47:11.354257 [ 1372 ] {903bf607-9506-424b-a3da-ca3e7070fb26} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 24. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0FF00000000000000001000000000000000300000000000000'), 'AggregateFunction(groupArrayMovingAvg, UInt64)')). (CANNOT_READ_ALL_DATA) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44894) (comment: 02477_invalid_reads.sql) (in query: SELECT finalizeAggregation(CAST(unhex('0FF00000000000000001000000000000000300000000000000'), 'AggregateFunction(groupArrayMovingAvg, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:157: DB::MovingImpl, DB::MovingAvgData>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002692864a 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 2025.04.02 01:47:11.356953 [ 1372 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 24. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0FF00000000000000001000000000000000300000000000000'), 'AggregateFunction(groupArrayMovingAvg, UInt64)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:157: DB::MovingImpl, DB::MovingAvgData>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002692864a 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 2025.04.02 01:47:12.191689 [ 1372 ] {31785485-b31f-46aa-9977-5e4fa9412b90} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 46. Bytes expected: 80.: In scope SELECT finalizeAggregation(CAST(unhex('00000000000024C000000000000018C00500000000000024C0000000000000F03F00000000000022C0000000000000F03F00000000000020C0000000000000'), 'AggregateFunction(histogram(5), Int64)')). (CANNOT_READ_ALL_DATA) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44894) (comment: 02477_invalid_reads.sql) (in query: -- Histogram SELECT finalizeAggregation(CAST(unhex('00000000000024C000000000000018C00500000000000024C0000000000000F03F00000000000022C0000000000000F03F00000000000020C0000000000000'), 'AggregateFunction(histogram(5), Int64)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionHistogram.cpp:309: DB::(anonymous namespace)::AggregateFunctionHistogramData::read(DB::ReadBuffer&, unsigned int) @ 0x0000000026626f2d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionHistogram.cpp:369: DB::(anonymous namespace)::AggregateFunctionHistogram::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002665fbc9 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 2025.04.02 01:47:12.194219 [ 1372 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 46. Bytes expected: 80.: In scope SELECT finalizeAggregation(CAST(unhex('00000000000024C000000000000018C00500000000000024C0000000000000F03F00000000000022C0000000000000F03F00000000000020C0000000000000'), 'AggregateFunction(histogram(5), Int64)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionHistogram.cpp:309: DB::(anonymous namespace)::AggregateFunctionHistogramData::read(DB::ReadBuffer&, unsigned int) @ 0x0000000026626f2d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionHistogram.cpp:369: DB::(anonymous namespace)::AggregateFunctionHistogram::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002665fbc9 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 2025.04.02 01:47:13.003548 [ 1372 ] {5f8d5656-49e9-4e9c-99b5-036a8b452193} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 56. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0F01000000000000244000000000000026400000000000002840000000000000244000000000000026400000000000002840000000000000F03F'), 'AggregateFunction(mannWhitneyUTest, Float64, UInt8)')). (CANNOT_READ_ALL_DATA) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44894) (comment: 02477_invalid_reads.sql) (in query: -- StatisticalSample SELECT finalizeAggregation(CAST(unhex('0F01000000000000244000000000000026400000000000002840000000000000244000000000000026400000000000002840000000000000F03F'), 'AggregateFunction(mannWhitneyUTest, Float64, UInt8)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./src/AggregateFunctions/StatCommon.h:116: DB::StatisticalSample::read(DB::ReadBuffer&, DB::Arena*) @ 0x0000000026a7773c 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionMannWhitney.cpp:228: DB::(anonymous namespace)::AggregateFunctionMannWhitney::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000026a81032 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 2025.04.02 01:47:13.005926 [ 1372 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 56. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0F01000000000000244000000000000026400000000000002840000000000000244000000000000026400000000000002840000000000000F03F'), 'AggregateFunction(mannWhitneyUTest, Float64, UInt8)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./src/AggregateFunctions/StatCommon.h:116: DB::StatisticalSample::read(DB::ReadBuffer&, DB::Arena*) @ 0x0000000026a7773c 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionMannWhitney.cpp:228: DB::(anonymous namespace)::AggregateFunctionMannWhitney::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000026a81032 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 2025.04.02 01:47:13.824708 [ 1372 ] {0d005b4c-188f-442d-9842-4870c66d35bb} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 64. Bytes expected: 240.: In scope SELECT finalizeAggregation(CAST(unhex('0F010000000000000001000000000000000300000000000000FFFFFFFFFFFFFFFF03340B9B047F000001000000000000000500000065000000FFFFFFFFFFFFFFFF'), 'AggregateFunction(maxIntersections, UInt8, UInt8)')). (CANNOT_READ_ALL_DATA) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44894) (comment: 02477_invalid_reads.sql) (in query: -- maxIntersections SELECT finalizeAggregation(CAST(unhex('0F010000000000000001000000000000000300000000000000FFFFFFFFFFFFFFFF03340B9B047F000001000000000000000500000065000000FFFFFFFFFFFFFFFF'), 'AggregateFunction(maxIntersections, UInt8, UInt8)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionMaxIntersections.cpp:153: DB::(anonymous namespace)::AggregateFunctionIntersectionsMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002657717a 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 2025.04.02 01:47:13.827220 [ 1372 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 64. Bytes expected: 240.: In scope SELECT finalizeAggregation(CAST(unhex('0F010000000000000001000000000000000300000000000000FFFFFFFFFFFFFFFF03340B9B047F000001000000000000000500000065000000FFFFFFFFFFFFFFFF'), 'AggregateFunction(maxIntersections, UInt8, UInt8)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionMaxIntersections.cpp:153: DB::(anonymous namespace)::AggregateFunctionIntersectionsMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002657717a 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 2025.04.02 01:47:14.656833 [ 1372 ] {5a800926-b26e-456d-a3af-41d7bba3ed60} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 44. Bytes expected: 65.: In scope SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1. (CANNOT_READ_ALL_DATA) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44894) (comment: 02477_invalid_reads.sql) (in query: -- sequenceNextNode (This was fine because it would fail in the next readBinary call, but better to add a test) SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(''forward'', ''head''), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:105: DB::(anonymous namespace)::NodeBase, 64ul>::read(DB::ReadBuffer&, DB::Arena*) @ 0x0000000026aa7e0e 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:345: DB::(anonymous namespace)::SequenceNextNodeImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000026ab426a 7. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:188: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000273421aa 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 9. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 10. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 11. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 13. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 14. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 2025.04.02 01:47:14.659779 [ 1372 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 44. Bytes expected: 65.: In scope SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:105: DB::(anonymous namespace)::NodeBase, 64ul>::read(DB::ReadBuffer&, DB::Arena*) @ 0x0000000026aa7e0e 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:345: DB::(anonymous namespace)::SequenceNextNodeImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000026ab426a 7. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:188: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000273421aa 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 9. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 10. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 11. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 13. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 14. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 2025.04.02 01:47:14.675315 [ 3554 ] {5c2234ff-33a8-4193-ab64-533230576fdb} executeQuery: Code: 582. DB::Exception: There is no projection pp in table. (NO_SUCH_PROJECTION_IN_TABLE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:55246) (comment: 01710_projection_drop_if_exists.sql) (in query: alter table tp drop projection pp;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a077ced 4. ./build_docker/./src/Storages/ProjectionsDescription.cpp:422: DB::ProjectionsDescription::remove(String const&, bool) @ 0x000000003c85c50b 5. ./build_docker/./src/Storages/AlterCommands.cpp:805: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003c6c0467 6. ./build_docker/./src/Storages/AlterCommands.cpp:1180: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003c6d7650 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3469: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003dea80a0 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:218: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775be7b 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 12. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 19. ? @ 0x00007f583d9b1ac3 20. ? @ 0x00007f583da43850 2025.04.02 01:47:14.677816 [ 3554 ] {} TCPHandler: Code: 582. DB::Exception: There is no projection pp in table. (NO_SUCH_PROJECTION_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a077ced 4. ./build_docker/./src/Storages/ProjectionsDescription.cpp:422: DB::ProjectionsDescription::remove(String const&, bool) @ 0x000000003c85c50b 5. ./build_docker/./src/Storages/AlterCommands.cpp:805: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003c6c0467 6. ./build_docker/./src/Storages/AlterCommands.cpp:1180: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003c6d7650 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3469: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003dea80a0 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:218: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775be7b 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 12. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 19. ? @ 0x00007f583d9b1ac3 20. ? @ 0x00007f583da43850 2025.04.02 01:47:14.837250 [ 3554 ] {d63fc361-f308-46f9-85a3-ac28c4f86fac} executeQuery: Code: 582. DB::Exception: There is no projection p in table. (NO_SUCH_PROJECTION_IN_TABLE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:55246) (comment: 01710_projection_drop_if_exists.sql) (in query: alter table tp drop projection p;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a077ced 4. ./build_docker/./src/Storages/ProjectionsDescription.cpp:422: DB::ProjectionsDescription::remove(String const&, bool) @ 0x000000003c85c50b 5. ./build_docker/./src/Storages/AlterCommands.cpp:805: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003c6c0467 6. ./build_docker/./src/Storages/AlterCommands.cpp:1180: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003c6d7650 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3469: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003dea80a0 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:218: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775be7b 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 12. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 19. ? @ 0x00007f583d9b1ac3 20. ? @ 0x00007f583da43850 2025.04.02 01:47:14.842563 [ 3554 ] {} TCPHandler: Code: 582. DB::Exception: There is no projection p in table. (NO_SUCH_PROJECTION_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a077ced 4. ./build_docker/./src/Storages/ProjectionsDescription.cpp:422: DB::ProjectionsDescription::remove(String const&, bool) @ 0x000000003c85c50b 5. ./build_docker/./src/Storages/AlterCommands.cpp:805: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003c6c0467 6. ./build_docker/./src/Storages/AlterCommands.cpp:1180: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003c6d7650 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3469: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003dea80a0 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:218: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775be7b 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 12. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 19. ? @ 0x00007f583d9b1ac3 20. ? @ 0x00007f583da43850 2025.04.02 01:47:15.474962 [ 1372 ] {bf1898fa-f5f1-4883-ae53-1428443d6850} executeQuery: Code: 128. DB::Exception: Too large node state size: In scope SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1. (TOO_LARGE_ARRAY_SIZE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44894) (comment: 02477_invalid_reads.sql) (in query: -- Fuzzer (ALL) SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:101: DB::(anonymous namespace)::NodeBase, 64ul>::read(DB::ReadBuffer&, DB::Arena*) @ 0x0000000026aa82f7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:345: DB::(anonymous namespace)::SequenceNextNodeImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000026ab426a 6. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:188: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000273421aa 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 2025.04.02 01:47:15.477752 [ 1372 ] {} TCPHandler: Code: 128. DB::Exception: Too large node state size: In scope SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1. (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:101: DB::(anonymous namespace)::NodeBase, 64ul>::read(DB::ReadBuffer&, DB::Arena*) @ 0x0000000026aa82f7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:345: DB::(anonymous namespace)::SequenceNextNodeImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000026ab426a 6. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:188: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000273421aa 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 2025.04.02 01:47:15.496174 [ 1372 ] {3d5e083d-849d-477b-aa86-4349e3b0db25} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 44. Bytes expected: 65.: In scope SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1. (CANNOT_READ_ALL_DATA) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44894) (comment: 02477_invalid_reads.sql) (in query: -- Fuzzer 2 (UBSAN) SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:105: DB::(anonymous namespace)::NodeBase, 64ul>::read(DB::ReadBuffer&, DB::Arena*) @ 0x0000000026aa7e0e 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:345: DB::(anonymous namespace)::SequenceNextNodeImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000026ab426a 7. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:188: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000273421aa 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 9. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 10. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 11. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 13. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 14. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 2025.04.02 01:47:15.498485 [ 1372 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 44. Bytes expected: 65.: In scope SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:105: DB::(anonymous namespace)::NodeBase, 64ul>::read(DB::ReadBuffer&, DB::Arena*) @ 0x0000000026aa7e0e 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:345: DB::(anonymous namespace)::SequenceNextNodeImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000026ab426a 7. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:188: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000273421aa 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 9. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 10. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 11. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 13. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 14. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 2025.04.02 01:47:15.763138 [ 2377 ] {412adde2-6b71-411b-94d6-47f0e0913d8d} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 2.00, current rows: 77.00: While executing EmbeddedRocksDB. (TOO_MANY_ROWS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:60890) (comment: 01504_rocksdb.sql) (in query: SELECT k, value FROM 01504_test WHERE k = 0 OR value > 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000034b9f797 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000034b9e42e 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000034b069b2 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:64: DB::ExecutionThreadContext::executeTask() @ 0x000000003f753b03 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003f71c8c3 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c2f5 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 13. ? @ 0x00007f583d9b1ac3 14. ? @ 0x00007f583da43850 2025.04.02 01:47:15.781788 [ 2377 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 2.00, current rows: 77.00: While executing EmbeddedRocksDB. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000034b9f797 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000034b9e42e 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000034b069b2 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:64: DB::ExecutionThreadContext::executeTask() @ 0x000000003f753b03 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003f71c8c3 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c2f5 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 13. ? @ 0x00007f583d9b1ac3 14. ? @ 0x00007f583da43850 2025.04.02 01:47:15.916259 [ 2377 ] {c54bf9ad-ace3-4950-a9a5-d8030cb280ab} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 2.00, current rows: 77.00: While executing EmbeddedRocksDB. (TOO_MANY_ROWS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:60890) (comment: 01504_rocksdb.sql) (in query: SELECT k, value FROM 01504_test WHERE k = 0 AND k IN (1, 3) OR k > 8;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000034b9f797 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000034b9e42e 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000034b069b2 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:64: DB::ExecutionThreadContext::executeTask() @ 0x000000003f753b03 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003f71c8c3 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c2f5 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 13. ? @ 0x00007f583d9b1ac3 14. ? @ 0x00007f583da43850 2025.04.02 01:47:15.933557 [ 2377 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 2.00, current rows: 77.00: While executing EmbeddedRocksDB. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000034b9f797 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000034b9e42e 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000034b069b2 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:64: DB::ExecutionThreadContext::executeTask() @ 0x000000003f753b03 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003f71c8c3 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c2f5 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 13. ? @ 0x00007f583d9b1ac3 14. ? @ 0x00007f583da43850 2025.04.02 01:47:16.369146 [ 1372 ] {3a37366e-48d2-4f66-a545-cb884df37cbd} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 8. Bytes expected: 32.: In scope SELECT finalizeAggregation(CAST(unhex('04128345AA2BC97190'), 'AggregateFunction(uniqUpTo(10), String)')). (CANNOT_READ_ALL_DATA) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44894) (comment: 02477_invalid_reads.sql) (in query: -- uniqUpTo SELECT finalizeAggregation(CAST(unhex('04128345AA2BC97190'), 'AggregateFunction(uniqUpTo(10), String)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionUniqUpTo.cpp:124: DB::(anonymous namespace)::AggregateFunctionUniqUpTo::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000260c14a7 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 2025.04.02 01:47:16.371881 [ 1372 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 8. Bytes expected: 32.: In scope SELECT finalizeAggregation(CAST(unhex('04128345AA2BC97190'), 'AggregateFunction(uniqUpTo(10), String)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionUniqUpTo.cpp:124: DB::(anonymous namespace)::AggregateFunctionUniqUpTo::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000260c14a7 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 2025.04.02 01:47:16.383720 [ 3161 ] {4766ea6c-296d-4491-9e9b-28191788ff3b} executeQuery: Code: 73. DB::Exception: Unknown format UnknownFormat. (UNKNOWN_FORMAT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:55318) (comment: 02311_create_table_with_unknown_format.sql) (in query: create table test_02311 (x UInt32) engine=File(UnknownFormat);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ac716ea 4. ./build_docker/./src/Formats/FormatFactory.cpp:912: DB::FormatFactory::checkFormatName(String const&) const @ 0x000000003f4f5577 5. ./build_docker/./src/Storages/StorageFile.cpp:1094: DB::StorageFile::StorageFile(DB::StorageFile::CommonArguments) @ 0x000000003c95d53d 6. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, DB::StorageFile::CommonArguments) @ 0x000000003c966069 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], String const&, DB::StorageFile::CommonArguments&, void>(std::allocator const&, String const&, DB::StorageFile::CommonArguments&) @ 0x000000003c9b8d53 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003c9a3b00 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003c9464fa 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377e8869 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:47:16.386337 [ 3161 ] {} TCPHandler: Code: 73. DB::Exception: Unknown format UnknownFormat. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ac716ea 4. ./build_docker/./src/Formats/FormatFactory.cpp:912: DB::FormatFactory::checkFormatName(String const&) const @ 0x000000003f4f5577 5. ./build_docker/./src/Storages/StorageFile.cpp:1094: DB::StorageFile::StorageFile(DB::StorageFile::CommonArguments) @ 0x000000003c95d53d 6. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, DB::StorageFile::CommonArguments) @ 0x000000003c966069 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], String const&, DB::StorageFile::CommonArguments&, void>(std::allocator const&, String const&, DB::StorageFile::CommonArguments&) @ 0x000000003c9b8d53 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003c9a3b00 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003c9464fa 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377e8869 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:47:17.096285 [ 3161 ] {9f918508-8df1-4984-97be-75962fb6198d} executeQuery: Code: 73. DB::Exception: Unknown format UnknownFormat. (UNKNOWN_FORMAT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:55318) (comment: 02311_create_table_with_unknown_format.sql) (in query: create table test_02311 (x UInt32) engine=URL('http://some/url', UnknownFormat);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ac716ea 4. ./build_docker/./src/Formats/FormatFactory.cpp:912: DB::FormatFactory::checkFormatName(String const&) const @ 0x000000003f4f5577 5. ./build_docker/./src/Storages/StorageURL.cpp:165: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x000000003d310668 6. ./build_docker/./src/Storages/StorageURL.cpp:1421: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x000000003d32ef1c 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageURL* std::construct_at[abi:v15007], String&, std::vector>&, String&, std::shared_ptr&, DB::StorageURL*>(DB::StorageURL*, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000003d35a170 8. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::shared_ptr std::allocate_shared[abi:v15007], String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, std::vector>&, String&, std::shared_ptr&, void>(std::allocator const&, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000003d359da9 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003d34ae94 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003c9464fa 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377e8869 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 16. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 17. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 23. ? @ 0x00007f583d9b1ac3 24. ? @ 0x00007f583da43850 2025.04.02 01:47:17.098823 [ 3161 ] {} TCPHandler: Code: 73. DB::Exception: Unknown format UnknownFormat. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ac716ea 4. ./build_docker/./src/Formats/FormatFactory.cpp:912: DB::FormatFactory::checkFormatName(String const&) const @ 0x000000003f4f5577 5. ./build_docker/./src/Storages/StorageURL.cpp:165: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x000000003d310668 6. ./build_docker/./src/Storages/StorageURL.cpp:1421: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x000000003d32ef1c 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageURL* std::construct_at[abi:v15007], String&, std::vector>&, String&, std::shared_ptr&, DB::StorageURL*>(DB::StorageURL*, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000003d35a170 8. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::shared_ptr std::allocate_shared[abi:v15007], String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, std::vector>&, String&, std::shared_ptr&, void>(std::allocator const&, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000003d359da9 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003d34ae94 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003c9464fa 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377e8869 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 16. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 17. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 23. ? @ 0x00007f583d9b1ac3 24. ? @ 0x00007f583da43850 2025.04.02 01:47:17.203464 [ 1372 ] {c0f7fa0b-7d87-436f-9a64-8c6d39b6d04f} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 8. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0F0000000000000000'), 'AggregateFunction(quantileExact, UInt64)')). (CANNOT_READ_ALL_DATA) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44894) (comment: 02477_invalid_reads.sql) (in query: -- quantiles SELECT finalizeAggregation(CAST(unhex('0F0000000000000000'), 'AggregateFunction(quantileExact, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./src/AggregateFunctions/QuantileExact.h:64: DB::QuantileExactBase>::deserialize(DB::ReadBuffer&) @ 0x00000000224cb62a 6. ./src/AggregateFunctions/AggregateFunctionQuantile.h:247: DB::AggregateFunctionQuantile, DB::NameQuantileExact, false, void, false, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000224c5c4f 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 2025.04.02 01:47:17.205929 [ 1372 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 8. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0F0000000000000000'), 'AggregateFunction(quantileExact, UInt64)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./src/AggregateFunctions/QuantileExact.h:64: DB::QuantileExactBase>::deserialize(DB::ReadBuffer&) @ 0x00000000224cb62a 6. ./src/AggregateFunctions/AggregateFunctionQuantile.h:247: DB::AggregateFunctionQuantile, DB::NameQuantileExact, false, void, false, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000224c5c4f 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 2025.04.02 01:47:17.626474 [ 3161 ] {e2754eb0-08aa-45af-8cd9-ef850b726bec} executeQuery: Code: 73. DB::Exception: Unknown format UnknownFormat. (UNKNOWN_FORMAT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:55318) (comment: 02311_create_table_with_unknown_format.sql) (in query: create table test_02311 (x UInt32) engine=S3('http://host:2020/test/data', UnknownFormat);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ac716ea 4. ./build_docker/./src/Formats/FormatFactory.cpp:912: DB::FormatFactory::checkFormatName(String const&) const @ 0x000000003f4f5577 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:585: DB::StorageObjectStorage::Configuration::initialize(DB::StorageObjectStorage::Configuration&, absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool, std::unique_ptr>) @ 0x00000000330ec596 6. ./build_docker/./src/Storages/ObjectStorage/registerStorageObjectStorage.cpp:48: DB::(anonymous namespace)::createStorageObjectStorage(DB::StorageFactory::Arguments const&, std::shared_ptr, std::shared_ptr) @ 0x000000003d4a44af 7. ./build_docker/./src/Storages/ObjectStorage/registerStorageObjectStorage.cpp:112: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003d4a5c66 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003c9464fa 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377e8869 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 14. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 15. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 21. ? @ 0x00007f583d9b1ac3 22. ? @ 0x00007f583da43850 2025.04.02 01:47:17.628880 [ 3161 ] {} TCPHandler: Code: 73. DB::Exception: Unknown format UnknownFormat. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ac716ea 4. ./build_docker/./src/Formats/FormatFactory.cpp:912: DB::FormatFactory::checkFormatName(String const&) const @ 0x000000003f4f5577 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:585: DB::StorageObjectStorage::Configuration::initialize(DB::StorageObjectStorage::Configuration&, absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool, std::unique_ptr>) @ 0x00000000330ec596 6. ./build_docker/./src/Storages/ObjectStorage/registerStorageObjectStorage.cpp:48: DB::(anonymous namespace)::createStorageObjectStorage(DB::StorageFactory::Arguments const&, std::shared_ptr, std::shared_ptr) @ 0x000000003d4a44af 7. ./build_docker/./src/Storages/ObjectStorage/registerStorageObjectStorage.cpp:112: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003d4a5c66 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003c9464fa 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377e8869 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 14. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 15. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 21. ? @ 0x00007f583d9b1ac3 22. ? @ 0x00007f583da43850 2025.04.02 01:47:18.036572 [ 1372 ] {7c316e25-b1a9-4c26-9cb4-0d8d1c62e57f} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 8. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0F000000000000803F'), 'AggregateFunction(quantileTDigest, UInt64)')). (CANNOT_READ_ALL_DATA) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44894) (comment: 02477_invalid_reads.sql) (in query: SELECT finalizeAggregation(CAST(unhex('0F000000000000803F'), 'AggregateFunction(quantileTDigest, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./src/AggregateFunctions/QuantileTDigest.h:319: DB::QuantileTDigest::deserialize(DB::ReadBuffer&) @ 0x00000000232b8c00 6. ./src/AggregateFunctions/AggregateFunctionQuantile.h:247: DB::AggregateFunctionQuantile, DB::NameQuantileTDigest, false, float, false, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000232ac00f 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 2025.04.02 01:47:18.039298 [ 1372 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 8. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0F000000000000803F'), 'AggregateFunction(quantileTDigest, UInt64)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f728dad 4. ./src/IO/ReadBuffer.h:196: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000020895a07 5. ./src/AggregateFunctions/QuantileTDigest.h:319: DB::QuantileTDigest::deserialize(DB::ReadBuffer&) @ 0x00000000232b8c00 6. ./src/AggregateFunctions/AggregateFunctionQuantile.h:247: DB::AggregateFunctionQuantile, DB::NameQuantileTDigest, false, float, false, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000232ac00f 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000034e496ad 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000034e49ebc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000031e41f6b 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000031e3f497 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000003248f83c 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d8cff2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 2025.04.02 01:47:18.170969 [ 3161 ] {374ae9d7-d667-475a-b1b9-281675d50824} executeQuery: Code: 73. DB::Exception: Unknown format UnknownFormat. (UNKNOWN_FORMAT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:55318) (comment: 02311_create_table_with_unknown_format.sql) (in query: create table test_02311 (x UInt32) engine=HDFS('http://hdfs:9000/data', UnknownFormat);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ac716ea 4. ./build_docker/./src/Formats/FormatFactory.cpp:912: DB::FormatFactory::checkFormatName(String const&) const @ 0x000000003f4f5577 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:585: DB::StorageObjectStorage::Configuration::initialize(DB::StorageObjectStorage::Configuration&, absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool, std::unique_ptr>) @ 0x00000000330ec596 6. ./build_docker/./src/Storages/ObjectStorage/registerStorageObjectStorage.cpp:48: DB::(anonymous namespace)::createStorageObjectStorage(DB::StorageFactory::Arguments const&, std::shared_ptr, std::shared_ptr) @ 0x000000003d4a44af 7. ./build_docker/./src/Storages/ObjectStorage/registerStorageObjectStorage.cpp:145: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003d4a61eb 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003c9464fa 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377e8869 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 14. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 15. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 21. ? @ 0x00007f583d9b1ac3 22. ? @ 0x00007f583da43850 2025.04.02 01:47:18.173405 [ 3161 ] {} TCPHandler: Code: 73. DB::Exception: Unknown format UnknownFormat. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ac716ea 4. ./build_docker/./src/Formats/FormatFactory.cpp:912: DB::FormatFactory::checkFormatName(String const&) const @ 0x000000003f4f5577 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:585: DB::StorageObjectStorage::Configuration::initialize(DB::StorageObjectStorage::Configuration&, absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool, std::unique_ptr>) @ 0x00000000330ec596 6. ./build_docker/./src/Storages/ObjectStorage/registerStorageObjectStorage.cpp:48: DB::(anonymous namespace)::createStorageObjectStorage(DB::StorageFactory::Arguments const&, std::shared_ptr, std::shared_ptr) @ 0x000000003d4a44af 7. ./build_docker/./src/Storages/ObjectStorage/registerStorageObjectStorage.cpp:145: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003d4a61eb 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003c9464fa 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377e8869 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 14. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 15. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 21. ? @ 0x00007f583d9b1ac3 22. ? @ 0x00007f583da43850 2025.04.02 01:47:19.613958 [ 2377 ] {83e5581f-c801-4bc1-81f6-4c07eca622d4} executeQuery: Code: 70. DB::Exception: Cannot convert out of range floating point value to integer type. (CANNOT_CONVERT_TYPE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:55414) (comment: 01804_uniq_up_to_ubsan.sql) (in query: SELECT uniqUpTo(1e100)(number) FROM numbers(5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./src/Common/FieldVisitorConvertToNumber.h:74: DB::FieldVisitorConvertToNumber::operator()(double const&) const @ 0x00000000206f8d8a 5. ./src/Core/Field.h:651: auto DB::Field::dispatch, DB::Field const&>(DB::FieldVisitorConvertToNumber&&, DB::Field const&) @ 0x0000000021f92bce 6. ./src/Common/FieldVisitors.h:24: DB::(anonymous namespace)::createAggregateFunctionUniqUpTo(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002601b6b8 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002132d0c3 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000032daf84d 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:129: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x0000000032da9f59 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3322: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9e826 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:47:19.616502 [ 2377 ] {} TCPHandler: Code: 70. DB::Exception: Cannot convert out of range floating point value to integer type. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./src/Common/FieldVisitorConvertToNumber.h:74: DB::FieldVisitorConvertToNumber::operator()(double const&) const @ 0x00000000206f8d8a 5. ./src/Core/Field.h:651: auto DB::Field::dispatch, DB::Field const&>(DB::FieldVisitorConvertToNumber&&, DB::Field const&) @ 0x0000000021f92bce 6. ./src/Common/FieldVisitors.h:24: DB::(anonymous namespace)::createAggregateFunctionUniqUpTo(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002601b6b8 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002132d0c3 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000032daf84d 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:129: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x0000000032da9f59 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3322: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9e826 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:47:19.633055 [ 2377 ] {d4e025d8-e674-455f-8823-ff0d36746ce6} executeQuery: Code: 70. DB::Exception: Cannot convert out of range floating point value to integer type. (CANNOT_CONVERT_TYPE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:55414) (comment: 01804_uniq_up_to_ubsan.sql) (in query: SELECT uniqUpTo(-1e100)(number) FROM numbers(5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./src/Common/FieldVisitorConvertToNumber.h:74: DB::FieldVisitorConvertToNumber::operator()(double const&) const @ 0x00000000206f8d8a 5. ./src/Core/Field.h:651: auto DB::Field::dispatch, DB::Field const&>(DB::FieldVisitorConvertToNumber&&, DB::Field const&) @ 0x0000000021f92bce 6. ./src/Common/FieldVisitors.h:24: DB::(anonymous namespace)::createAggregateFunctionUniqUpTo(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002601b6b8 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002132d0c3 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000032daf84d 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:129: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x0000000032da9f59 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3322: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9e826 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:47:19.635719 [ 2377 ] {} TCPHandler: Code: 70. DB::Exception: Cannot convert out of range floating point value to integer type. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./src/Common/FieldVisitorConvertToNumber.h:74: DB::FieldVisitorConvertToNumber::operator()(double const&) const @ 0x00000000206f8d8a 5. ./src/Core/Field.h:651: auto DB::Field::dispatch, DB::Field const&>(DB::FieldVisitorConvertToNumber&&, DB::Field const&) @ 0x0000000021f92bce 6. ./src/Common/FieldVisitors.h:24: DB::(anonymous namespace)::createAggregateFunctionUniqUpTo(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002601b6b8 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002132d0c3 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000032daf84d 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:129: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x0000000032da9f59 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3322: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9e826 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:47:23.219693 [ 1429 ] {3c236348-5f56-46ea-9f04-f2ebfb2f7159} executeQuery: Code: 36. DB::Exception: Bidirectional can only be applied to hierarchical attributes. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:55826) (comment: 02294_dictionaries_hierarchical_index.sql) (in query: CREATE DICTIONARY hierarchy_flat_dictionary_index ( id UInt64, parent_id UInt64 BIDIRECTIONAL ) PRIMARY KEY id SOURCE(CLICKHOUSE(TABLE 'test_hierarchy_source_table')) LAYOUT(FLAT()) LIFETIME(0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Dictionaries/DictionaryStructure.cpp:365: DB::DictionaryStructure::getAttributes(Poco::Util::AbstractConfiguration const&, String const&, bool) @ 0x0000000031be504d 5. ./build_docker/./src/Dictionaries/DictionaryStructure.cpp:97: DB::DictionaryStructure::DictionaryStructure(Poco::Util::AbstractConfiguration const&, String const&) @ 0x0000000031bda511 6. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:214: DB::ExternalDictionariesLoader::getDictionaryStructure(Poco::Util::AbstractConfiguration const&, String const&) @ 0x000000003768bdfc 7. ./build_docker/./src/Storages/StorageDictionary.cpp:137: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, Poco::AutoPtr, std::shared_ptr) @ 0x000000003c8948bf 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15007]&, std::shared_ptr&>(std::allocator, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x000000003c8a224a 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&, void>(std::allocator const&, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x000000003c8a1f43 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003c89d987 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003c9464fa 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377e8869 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 17. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 18. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 24. ? @ 0x00007f583d9b1ac3 25. ? @ 0x00007f583da43850 2025.04.02 01:47:23.232641 [ 1429 ] {} TCPHandler: Code: 36. DB::Exception: Bidirectional can only be applied to hierarchical attributes. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Dictionaries/DictionaryStructure.cpp:365: DB::DictionaryStructure::getAttributes(Poco::Util::AbstractConfiguration const&, String const&, bool) @ 0x0000000031be504d 5. ./build_docker/./src/Dictionaries/DictionaryStructure.cpp:97: DB::DictionaryStructure::DictionaryStructure(Poco::Util::AbstractConfiguration const&, String const&) @ 0x0000000031bda511 6. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:214: DB::ExternalDictionariesLoader::getDictionaryStructure(Poco::Util::AbstractConfiguration const&, String const&) @ 0x000000003768bdfc 7. ./build_docker/./src/Storages/StorageDictionary.cpp:137: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, Poco::AutoPtr, std::shared_ptr) @ 0x000000003c8948bf 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15007]&, std::shared_ptr&>(std::allocator, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x000000003c8a224a 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&, void>(std::allocator const&, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x000000003c8a1f43 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003c89d987 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003c9464fa 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377e8869 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 17. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 18. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 24. ? @ 0x00007f583d9b1ac3 25. ? @ 0x00007f583da43850 2025.04.02 01:47:23.557484 [ 3554 ] {0dd4e722-b1e9-48c3-90d8-68fb16b80d87} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toUnixTimestamp(toDateTime64('1928-12-31 12:12:12.123', 3, 'UTC')). (DECIMAL_OVERFLOW) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:55814) (comment: 02507_to_unix_timestamp_overflow.sql) (in query: SELECT toUnixTimestamp(toDateTime64('1928-12-31 12:12:12.123', 3, 'UTC'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./src/Core/DecimalFunctions.h:354: _ZN2DB18convertFromDecimalINS_18DataTypeDateTime64ENS_14DataTypeNumberIjEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEES6_RKNS4_9FieldTypeEj @ 0x0000000034ce72b9 5. ./src/Functions/FunctionsConversion.h:1760: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToUnixTimestamp, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000032a39cca 6. ./src/Functions/FunctionsConversion.h:2451: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000032513e02 7. ./src/Functions/FunctionsConversion.h:2511: DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003258ba49 8. ./src/Functions/FunctionsConversion.h:2292: DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003258a642 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 31. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 2025.04.02 01:47:23.560400 [ 3554 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toUnixTimestamp(toDateTime64('1928-12-31 12:12:12.123', 3, 'UTC')). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./src/Core/DecimalFunctions.h:354: _ZN2DB18convertFromDecimalINS_18DataTypeDateTime64ENS_14DataTypeNumberIjEEQaa17IsDataTypeDecimalIT_E15is_arithmetic_vINT0_9FieldTypeEEEES6_RKNS4_9FieldTypeEj @ 0x0000000034ce72b9 5. ./src/Functions/FunctionsConversion.h:1760: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToUnixTimestamp, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000032a39cca 6. ./src/Functions/FunctionsConversion.h:2451: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000032513e02 7. ./src/Functions/FunctionsConversion.h:2511: DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003258ba49 8. ./src/Functions/FunctionsConversion.h:2292: DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003258a642 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 31. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 2025.04.02 01:47:26.835661 [ 1429 ] {6af46f39-f8fa-43e0-8826-2f34844cf6b1} executeQuery: Code: 574. DB::Exception: Too many bytes pending for async INSERT: 5.04 KiB (bytes_to_throw_insert=1.00 B). (DISTRIBUTED_TOO_MANY_PENDING_BYTES) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:55982) (comment: 01670_distributed_bytes_to_throw_insert.sql) (in query: -- second will fail, because of bytes_to_throw_insert=1 -- (previous block definitelly takes more, since it has header) insert into dist_01670 select * from numbers(1) settings prefer_localhost_replica=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1835: DB::StorageDistributed::delayInsertOrThrowIfNeeded() const @ 0x000000003c901fab 5. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:170: DB::DistributedSink::consume(DB::Chunk&) @ 0x000000003d9d127e 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:18: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000040447b99 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x00000000400e14d9 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000400e0ff6 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x00000000400dfcc7 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003f7213f8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002097cef4 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002098fd26 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002098fadf 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:47:26.841072 [ 1429 ] {} TCPHandler: Code: 574. DB::Exception: Too many bytes pending for async INSERT: 5.04 KiB (bytes_to_throw_insert=1.00 B). (DISTRIBUTED_TOO_MANY_PENDING_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1835: DB::StorageDistributed::delayInsertOrThrowIfNeeded() const @ 0x000000003c901fab 5. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:170: DB::DistributedSink::consume(DB::Chunk&) @ 0x000000003d9d127e 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:18: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000040447b99 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x00000000400e14d9 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000400e0ff6 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x00000000400dfcc7 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003f7213f8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002097cef4 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002098fd26 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002098fadf 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:47:27.895803 [ 1429 ] {544e2b5e-064c-4af3-9606-6aa73c4fbbc7} executeQuery: Code: 81. DB::Exception: Database test_2462 does not exist. (UNKNOWN_DATABASE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:56046) (comment: 01444_create_table_drop_database_race.sh) (in query: CREATE TABLE IF NOT EXISTS test_2462.t6480 (`x` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 44598, min_bytes_for_wide_part = 904724198, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 96, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 437988003, compact_parts_max_granules_to_buffer = 181, compact_parts_merge_max_bytes_to_prefetch_part = 25483296, merge_max_block_size = 19780, old_parts_lifetime = 100., prefer_fetch_merged_part_size_threshold = 4837764282, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 22166239, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 39771, primary_key_compress_block_size = 75898, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ce483 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:47:27.895808 [ 3076 ] {61d79d5e-e150-49db-9943-d4c09feff71a} executeQuery: Code: 81. DB::Exception: Database test_2462 does not exist. (UNKNOWN_DATABASE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:56022) (comment: 01444_create_table_drop_database_race.sh) (in query: CREATE TABLE IF NOT EXISTS test_2462.t23647 (`x` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 44598, min_bytes_for_wide_part = 904724198, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 96, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 437988003, compact_parts_max_granules_to_buffer = 181, compact_parts_merge_max_bytes_to_prefetch_part = 25483296, merge_max_block_size = 19780, old_parts_lifetime = 100., prefer_fetch_merged_part_size_threshold = 4837764282, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 22166239, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 39771, primary_key_compress_block_size = 75898, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ce483 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:47:27.899433 [ 1429 ] {} TCPHandler: Code: 81. DB::Exception: Database test_2462 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ce483 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:47:27.902993 [ 3076 ] {} TCPHandler: Code: 81. DB::Exception: Database test_2462 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ce483 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:47:28.930250 [ 3554 ] {d78dcf3a-d988-4021-9618-8817c3776076} executeQuery: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:55986) (comment: 02864_statistics_predicates.sql) (in query: SELECT count(*) FROM tab WHERE u64 = '7.7';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a077ced 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:582: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391b308b 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391aa11e 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e4df899 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e48e04d 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000035b12641 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000035b0e123 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:26: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x00000000400ed969 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000004078848e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x00000000385b7b64 18. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000038679845 19. ./build_docker/./src/Planner/Planner.cpp:1622: DB::Planner::buildPlanForQueryNode() @ 0x0000000038660dc5 20. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:47:28.934071 [ 3554 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a077ced 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:582: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391b308b 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391aa11e 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e4df899 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e48e04d 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000035b12641 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000035b0e123 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:26: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x00000000400ed969 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000004078848e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x00000000385b7b64 18. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000038679845 19. ./build_docker/./src/Planner/Planner.cpp:1622: DB::Planner::buildPlanForQueryNode() @ 0x0000000038660dc5 20. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:47:28.964722 [ 3554 ] {5588bd4c-d0f6-467a-b821-1a515739f7f3} executeQuery: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:55986) (comment: 02864_statistics_predicates.sql) (in query: SELECT count(*) FROM tab WHERE u64_tdigest = '7.7';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a077ced 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:582: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391b308b 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391aa11e 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e4df899 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e48e04d 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000035b12641 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000035b0e123 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:26: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x00000000400ed969 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000004078848e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x00000000385b7b64 18. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000038679845 19. ./build_docker/./src/Planner/Planner.cpp:1622: DB::Planner::buildPlanForQueryNode() @ 0x0000000038660dc5 20. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:47:28.967582 [ 3554 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a077ced 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:582: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391b308b 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391aa11e 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e4df899 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e48e04d 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000035b12641 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000035b0e123 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:26: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x00000000400ed969 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000004078848e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x00000000385b7b64 18. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000038679845 19. ./build_docker/./src/Planner/Planner.cpp:1622: DB::Planner::buildPlanForQueryNode() @ 0x0000000038660dc5 20. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:47:28.993633 [ 3554 ] {5fa7150a-4eb7-46a5-a128-448990ffaf84} executeQuery: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:55986) (comment: 02864_statistics_predicates.sql) (in query: SELECT count(*) FROM tab WHERE u64_minmax = '7.7';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a077ced 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:582: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391b308b 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391aa11e 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e4df899 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e48e04d 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000035b12641 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000035b0e123 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:26: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x00000000400ed969 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000004078848e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x00000000385b7b64 18. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000038679845 19. ./build_docker/./src/Planner/Planner.cpp:1622: DB::Planner::buildPlanForQueryNode() @ 0x0000000038660dc5 20. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:47:28.996542 [ 3554 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a077ced 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:582: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391b308b 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391aa11e 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e4df899 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e48e04d 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000035b12641 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000035b0e123 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:26: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x00000000400ed969 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000004078848e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x00000000385b7b64 18. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000038679845 19. ./build_docker/./src/Planner/Planner.cpp:1622: DB::Planner::buildPlanForQueryNode() @ 0x0000000038660dc5 20. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:47:29.021978 [ 3554 ] {29cfc33a-f93b-4c30-bb22-d3d0d9c13841} executeQuery: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:55986) (comment: 02864_statistics_predicates.sql) (in query: SELECT count(*) FROM tab WHERE u64_countmin = '7.7';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a077ced 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:582: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391b308b 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391aa11e 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e4df899 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e48e04d 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000035b12641 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000035b0e123 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:26: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x00000000400ed969 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000004078848e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x00000000385b7b64 18. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000038679845 19. ./build_docker/./src/Planner/Planner.cpp:1622: DB::Planner::buildPlanForQueryNode() @ 0x0000000038660dc5 20. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:47:29.025045 [ 3554 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a077ced 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:582: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391b308b 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391aa11e 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e4df899 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e48e04d 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000035b12641 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000035b0e123 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:26: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x00000000400ed969 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000004078848e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x00000000385b7b64 18. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000038679845 19. ./build_docker/./src/Planner/Planner.cpp:1622: DB::Planner::buildPlanForQueryNode() @ 0x0000000038660dc5 20. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:47:29.049567 [ 3554 ] {ee16e3c7-731f-4127-8094-3ef09aac278e} executeQuery: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:55986) (comment: 02864_statistics_predicates.sql) (in query: SELECT count(*) FROM tab WHERE u64_uniq = '7.7';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a077ced 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:582: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391b308b 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391aa11e 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e4df899 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e48e04d 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000035b12641 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000035b0e123 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:26: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x00000000400ed969 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000004078848e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x00000000385b7b64 18. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000038679845 19. ./build_docker/./src/Planner/Planner.cpp:1622: DB::Planner::buildPlanForQueryNode() @ 0x0000000038660dc5 20. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:47:29.053506 [ 3554 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a077ced 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:582: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391b308b 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391aa11e 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e4df899 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e48e04d 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000035b12641 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000035b0e123 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:26: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x00000000400ed969 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000004078848e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x00000000385b7b64 18. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000038679845 19. ./build_docker/./src/Planner/Planner.cpp:1622: DB::Planner::buildPlanForQueryNode() @ 0x0000000038660dc5 20. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:47:29.340790 [ 4457 ] {807e534b-ac4e-4b4b-8596-f622136bc076} executeQuery: Code: 36. DB::Exception: Cannot alter settings, because table engine doesn't support settings changes. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:56112) (comment: 01089_alter_settings_old_format.sql) (in query: ALTER TABLE old_format_mt MODIFY SETTING enable_mixed_granularity_parts = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Storages/AlterCommands.cpp:1551: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003c6e6f03 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775bdb6 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:47:29.345477 [ 4457 ] {} TCPHandler: Code: 36. DB::Exception: Cannot alter settings, because table engine doesn't support settings changes. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Storages/AlterCommands.cpp:1551: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003c6e6f03 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775bdb6 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:47:29.471904 [ 3076 ] {647a103c-2778-40d8-b9f3-be2522b27b45} executeQuery: Code: 81. DB::Exception: Database test_2462 does not exist. (UNKNOWN_DATABASE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:56128) (comment: 01444_create_table_drop_database_race.sh) (in query: CREATE TABLE IF NOT EXISTS test_2462.t14957 (`x` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 44598, min_bytes_for_wide_part = 904724198, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 96, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 437988003, compact_parts_max_granules_to_buffer = 181, compact_parts_merge_max_bytes_to_prefetch_part = 25483296, merge_max_block_size = 19780, old_parts_lifetime = 100., prefer_fetch_merged_part_size_threshold = 4837764282, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 22166239, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 39771, primary_key_compress_block_size = 75898, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ce483 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:47:29.477132 [ 3076 ] {} TCPHandler: Code: 81. DB::Exception: Database test_2462 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ce483 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:47:29.517588 [ 1372 ] {81c708c6-59c3-46a1-bc52-6677ef2d4f79} executeQuery: Code: 81. DB::Exception: Database test_2462 does not exist. (UNKNOWN_DATABASE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:56130) (comment: 01444_create_table_drop_database_race.sh) (in query: CREATE TABLE IF NOT EXISTS test_2462.t26263 (`x` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 44598, min_bytes_for_wide_part = 904724198, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 96, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 437988003, compact_parts_max_granules_to_buffer = 181, compact_parts_merge_max_bytes_to_prefetch_part = 25483296, merge_max_block_size = 19780, old_parts_lifetime = 100., prefer_fetch_merged_part_size_threshold = 4837764282, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 22166239, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 39771, primary_key_compress_block_size = 75898, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ce483 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:47:29.521661 [ 1372 ] {} TCPHandler: Code: 81. DB::Exception: Database test_2462 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ce483 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:47:30.390490 [ 4457 ] {5d293a22-9903-4593-ab23-6ec0ebc0c46a} executeQuery: Code: 81. DB::Exception: Database test_2462 does not exist. (UNKNOWN_DATABASE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:56904) (comment: 01444_create_table_drop_database_race.sh) (in query: CREATE TABLE IF NOT EXISTS test_2462.t31993 (`x` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 44598, min_bytes_for_wide_part = 904724198, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 96, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 437988003, compact_parts_max_granules_to_buffer = 181, compact_parts_merge_max_bytes_to_prefetch_part = 25483296, merge_max_block_size = 19780, old_parts_lifetime = 100., prefer_fetch_merged_part_size_threshold = 4837764282, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 22166239, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 39771, primary_key_compress_block_size = 75898, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ce483 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:47:30.393722 [ 4457 ] {} TCPHandler: Code: 81. DB::Exception: Database test_2462 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ce483 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:47:30.984101 [ 4457 ] {a5ffdc4f-78c3-4245-9f8b-c56d5229fddd} executeQuery: Code: 81. DB::Exception: Database test_2462 does not exist. (UNKNOWN_DATABASE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:56910) (comment: 01444_create_table_drop_database_race.sh) (in query: CREATE TABLE IF NOT EXISTS test_2462.t15250 (`x` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 44598, min_bytes_for_wide_part = 904724198, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 96, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 437988003, compact_parts_max_granules_to_buffer = 181, compact_parts_merge_max_bytes_to_prefetch_part = 25483296, merge_max_block_size = 19780, old_parts_lifetime = 100., prefer_fetch_merged_part_size_threshold = 4837764282, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 22166239, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 39771, primary_key_compress_block_size = 75898, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ce483 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:47:30.987491 [ 4457 ] {} TCPHandler: Code: 81. DB::Exception: Database test_2462 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ce483 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:47:31.093338 [ 3076 ] {830f3c2e-be12-4ccd-8d56-d5edef7a481e} executeQuery: Code: 407. DB::Exception: Numeric overflow: while executing 'FUNCTION plus(toDateTime(toStartOfFifteenMinutes(plus(_CAST(1000_DateTime, 'DateTime'_String), multiply(__table2.number, 65536_UInt32)))) :: 3, multiply(__table2.number, 9223372036854775807_UInt64) :: 2) -> plus(toDateTime(toStartOfFifteenMinutes(plus(_CAST(1000_DateTime, 'DateTime'_String), multiply(__table2.number, 65536_UInt32)))), multiply(__table2.number, 9223372036854775807_UInt64)) DateTime : 0'. (DECIMAL_OVERFLOW) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:56872) (comment: 01680_date_time_add_ubsan.sql) (in query: SELECT DISTINCT result FROM (SELECT toStartOfFifteenMinutes(toDateTime(toStartOfFifteenMinutes(toDateTime(1000.0001220703125) + (number * 65536))) + (number * 9223372036854775807)) AS result FROM system.numbers LIMIT 1048576) ORDER BY result DESC NULLS FIRST FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000af31f13 5. void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000af2f2b4 6. DB::DateTimeAddIntervalImpl::execute(DB::AddSecondsImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000af1cab7 7. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000af189df 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 13. DB::FunctionBinaryArithmetic::executeDateTimeIntervalPlusMinus(std::vector> const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&) const @ 0x000000001972c6bf 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019729729 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x00000000400e3001 21. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027d13b04 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003f6df04b 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003f71c8c3 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c2f5 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 30. ? @ 0x00007f583d9b1ac3 31. ? @ 0x00007f583da43850 2025.04.02 01:47:31.098518 [ 3076 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: while executing 'FUNCTION plus(toDateTime(toStartOfFifteenMinutes(plus(_CAST(1000_DateTime, 'DateTime'_String), multiply(__table2.number, 65536_UInt32)))) :: 3, multiply(__table2.number, 9223372036854775807_UInt64) :: 2) -> plus(toDateTime(toStartOfFifteenMinutes(plus(_CAST(1000_DateTime, 'DateTime'_String), multiply(__table2.number, 65536_UInt32)))), multiply(__table2.number, 9223372036854775807_UInt64)) DateTime : 0'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000af31f13 5. void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000af2f2b4 6. DB::DateTimeAddIntervalImpl::execute(DB::AddSecondsImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000af1cab7 7. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000af189df 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 13. DB::FunctionBinaryArithmetic::executeDateTimeIntervalPlusMinus(std::vector> const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&) const @ 0x000000001972c6bf 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019729729 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x00000000400e3001 21. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027d13b04 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003f6df04b 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003f71c8c3 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c2f5 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 30. ? @ 0x00007f583d9b1ac3 31. ? @ 0x00007f583da43850 2025.04.02 01:47:31.662035 [ 3554 ] {acd8fc16-9bc3-4f6f-8c26-622d1ea30104} executeQuery: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:55986) (comment: 02864_statistics_predicates.sql) (in query: SELECT count(*) FROM tab WHERE u64 < '7.7';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a077ced 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:582: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391b308b 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391aa11e 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013d975d9 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013d4616d 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000035b12641 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000035b0e123 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:26: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x00000000400ed969 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000004078848e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x00000000385b7b64 18. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000038679845 19. ./build_docker/./src/Planner/Planner.cpp:1622: DB::Planner::buildPlanForQueryNode() @ 0x0000000038660dc5 20. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:47:31.665740 [ 3554 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a077ced 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:582: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391b308b 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391aa11e 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013d975d9 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013d4616d 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000035b12641 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000035b0e123 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:26: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x00000000400ed969 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000004078848e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x00000000385b7b64 18. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000038679845 19. ./build_docker/./src/Planner/Planner.cpp:1622: DB::Planner::buildPlanForQueryNode() @ 0x0000000038660dc5 20. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:47:31.692023 [ 3554 ] {1ec7432d-25be-4e5f-9e7f-464f6d4718ec} executeQuery: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:55986) (comment: 02864_statistics_predicates.sql) (in query: SELECT count(*) FROM tab WHERE u64_tdigest < '7.7';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a077ced 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:582: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391b308b 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391aa11e 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013d975d9 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013d4616d 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000035b12641 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000035b0e123 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:26: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x00000000400ed969 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000004078848e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x00000000385b7b64 18. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000038679845 19. ./build_docker/./src/Planner/Planner.cpp:1622: DB::Planner::buildPlanForQueryNode() @ 0x0000000038660dc5 20. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:47:31.695516 [ 3554 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a077ced 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:582: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391b308b 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391aa11e 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013d975d9 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013d4616d 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000035b12641 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000035b0e123 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:26: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x00000000400ed969 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000004078848e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x00000000385b7b64 18. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000038679845 19. ./build_docker/./src/Planner/Planner.cpp:1622: DB::Planner::buildPlanForQueryNode() @ 0x0000000038660dc5 20. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:47:31.722281 [ 3554 ] {39101879-1207-40a6-bf5f-c43a93b7bb13} executeQuery: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:55986) (comment: 02864_statistics_predicates.sql) (in query: SELECT count(*) FROM tab WHERE u64_minmax < '7.7';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a077ced 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:582: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391b308b 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391aa11e 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013d975d9 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013d4616d 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000035b12641 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000035b0e123 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:26: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x00000000400ed969 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000004078848e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x00000000385b7b64 18. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000038679845 19. ./build_docker/./src/Planner/Planner.cpp:1622: DB::Planner::buildPlanForQueryNode() @ 0x0000000038660dc5 20. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:47:31.724987 [ 3554 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a077ced 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:582: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391b308b 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391aa11e 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013d975d9 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013d4616d 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000035b12641 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000035b0e123 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:26: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x00000000400ed969 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000004078848e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x00000000385b7b64 18. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000038679845 19. ./build_docker/./src/Planner/Planner.cpp:1622: DB::Planner::buildPlanForQueryNode() @ 0x0000000038660dc5 20. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:47:31.749671 [ 3554 ] {a3ddc664-d0bd-4389-8270-56dd379bebb6} executeQuery: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:55986) (comment: 02864_statistics_predicates.sql) (in query: SELECT count(*) FROM tab WHERE u64_countmin < '7.7';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a077ced 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:582: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391b308b 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391aa11e 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013d975d9 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013d4616d 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000035b12641 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000035b0e123 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:26: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x00000000400ed969 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000004078848e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x00000000385b7b64 18. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000038679845 19. ./build_docker/./src/Planner/Planner.cpp:1622: DB::Planner::buildPlanForQueryNode() @ 0x0000000038660dc5 20. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:47:31.752358 [ 3554 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a077ced 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:582: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391b308b 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391aa11e 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013d975d9 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013d4616d 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000035b12641 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000035b0e123 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:26: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x00000000400ed969 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000004078848e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x00000000385b7b64 18. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000038679845 19. ./build_docker/./src/Planner/Planner.cpp:1622: DB::Planner::buildPlanForQueryNode() @ 0x0000000038660dc5 20. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:47:31.778670 [ 3554 ] {f24993d7-8910-49d5-996f-015bcf034427} executeQuery: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:55986) (comment: 02864_statistics_predicates.sql) (in query: SELECT count(*) FROM tab WHERE u64_uniq < '7.7';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a077ced 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:582: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391b308b 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391aa11e 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013d975d9 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013d4616d 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000035b12641 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000035b0e123 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:26: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x00000000400ed969 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000004078848e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x00000000385b7b64 18. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000038679845 19. ./build_docker/./src/Planner/Planner.cpp:1622: DB::Planner::buildPlanForQueryNode() @ 0x0000000038660dc5 20. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:47:31.781439 [ 3554 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a077ced 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:582: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391b308b 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391aa11e 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013d975d9 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013d4616d 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000035b12641 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000035b0e123 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:26: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x00000000400ed969 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000004078848e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x00000000385b7b64 18. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000038679845 19. ./build_docker/./src/Planner/Planner.cpp:1622: DB::Planner::buildPlanForQueryNode() @ 0x0000000038660dc5 20. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:47:31.916466 [ 3300 ] {a553435f-bc2d-46fd-85b1-f53b8b8573c0} executeQuery: Code: 81. DB::Exception: Database test_2462 does not exist. (UNKNOWN_DATABASE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:56982) (comment: 01444_create_table_drop_database_race.sh) (in query: CREATE TABLE IF NOT EXISTS test_2462.t32654 (`x` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 44598, min_bytes_for_wide_part = 904724198, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 96, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 437988003, compact_parts_max_granules_to_buffer = 181, compact_parts_merge_max_bytes_to_prefetch_part = 25483296, merge_max_block_size = 19780, old_parts_lifetime = 100., prefer_fetch_merged_part_size_threshold = 4837764282, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 22166239, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 39771, primary_key_compress_block_size = 75898, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ce483 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:47:31.919597 [ 3300 ] {} TCPHandler: Code: 81. DB::Exception: Database test_2462 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ce483 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:47:31.940159 [ 1372 ] {c2749639-c3d7-4ac4-92d0-8a702358f6fd} executeQuery: Code: 81. DB::Exception: Database test_2462 does not exist. (UNKNOWN_DATABASE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:56998) (comment: 01444_create_table_drop_database_race.sh) (in query: CREATE TABLE IF NOT EXISTS test_2462.t24708 (`x` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 44598, min_bytes_for_wide_part = 904724198, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 96, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 437988003, compact_parts_max_granules_to_buffer = 181, compact_parts_merge_max_bytes_to_prefetch_part = 25483296, merge_max_block_size = 19780, old_parts_lifetime = 100., prefer_fetch_merged_part_size_threshold = 4837764282, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 22166239, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 39771, primary_key_compress_block_size = 75898, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ce483 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:47:31.943619 [ 1372 ] {} TCPHandler: Code: 81. DB::Exception: Database test_2462 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ce483 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:47:33.501517 [ 423 ] {acddb6fd-fc7e-4fb6-b199-a79375c61e77} executeQuery: Code: 81. DB::Exception: Database test_2462 does not exist. (UNKNOWN_DATABASE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:57058) (comment: 01444_create_table_drop_database_race.sh) (in query: CREATE TABLE IF NOT EXISTS test_2462.t12400 (`x` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 44598, min_bytes_for_wide_part = 904724198, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 96, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 437988003, compact_parts_max_granules_to_buffer = 181, compact_parts_merge_max_bytes_to_prefetch_part = 25483296, merge_max_block_size = 19780, old_parts_lifetime = 100., prefer_fetch_merged_part_size_threshold = 4837764282, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 22166239, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 39771, primary_key_compress_block_size = 75898, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ce483 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:47:33.504862 [ 423 ] {} TCPHandler: Code: 81. DB::Exception: Database test_2462 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ce483 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:47:33.515312 [ 3076 ] {b66a3c9c-7d61-48a0-bad3-8312f2935d0b} executeQuery: Code: 81. DB::Exception: Database test_2462 does not exist. (UNKNOWN_DATABASE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:57062) (comment: 01444_create_table_drop_database_race.sh) (in query: CREATE TABLE IF NOT EXISTS test_2462.t9958 (`x` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 44598, min_bytes_for_wide_part = 904724198, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 96, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 437988003, compact_parts_max_granules_to_buffer = 181, compact_parts_merge_max_bytes_to_prefetch_part = 25483296, merge_max_block_size = 19780, old_parts_lifetime = 100., prefer_fetch_merged_part_size_threshold = 4837764282, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 22166239, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 39771, primary_key_compress_block_size = 75898, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ce483 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:47:33.520088 [ 3076 ] {} TCPHandler: Code: 81. DB::Exception: Database test_2462 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ce483 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:47:33.669843 [ 1429 ] {ebc74717-4f6b-49a5-8cef-29fe0ce1399b} executeQuery: Code: 53. DB::Exception: Cannot convert string 'default.table_name' to type Int32: While processing n IN ('default.table_name') AS m: default expression and column type are incompatible. (TYPE_MISMATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:57012) (comment: 02433_default_expression_operator_in.sql) (in query: -- Ensure that a table name cannot be passed to IN as string literal create table test (n int, m default n in 'default.table_name') engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a077ced 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:582: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391b308b 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391aa11e 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:671: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x00000000391b433e 7. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:130: std::vector> DB::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, bool) @ 0x0000000036a4137a 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:341: DB::makeExplicitSet(DB::ASTFunction const*, DB::ActionsDAG const&, std::shared_ptr, DB::PreparedSets&) @ 0x0000000036a046a2 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1504: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x0000000036a3a9a4 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:975: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a202de 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:732: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a1d275 12. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000369f7f95 13. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000036972ab7 14. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1859: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x00000000369a8a73 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1894: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x00000000369a9712 16. ./build_docker/./src/Storages/ColumnsDescription.cpp:1017: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x000000003c73559c 17. ./build_docker/./src/Storages/ColumnsDescription.cpp:1043: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000003c7368f3 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:670: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779acad 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:47:33.672240 [ 1429 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string 'default.table_name' to type Int32: While processing n IN ('default.table_name') AS m: default expression and column type are incompatible. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a077ced 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:582: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391b308b 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391aa11e 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:671: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x00000000391b433e 7. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:130: std::vector> DB::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, bool) @ 0x0000000036a4137a 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:341: DB::makeExplicitSet(DB::ASTFunction const*, DB::ActionsDAG const&, std::shared_ptr, DB::PreparedSets&) @ 0x0000000036a046a2 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1504: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x0000000036a3a9a4 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:975: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a202de 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:732: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a1d275 12. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000369f7f95 13. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000036972ab7 14. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1859: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x00000000369a8a73 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1894: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x00000000369a9712 16. ./build_docker/./src/Storages/ColumnsDescription.cpp:1017: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x000000003c73559c 17. ./build_docker/./src/Storages/ColumnsDescription.cpp:1043: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000003c7368f3 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:670: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779acad 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:47:33.686017 [ 1429 ] {37d4504e-e225-48e3-88ca-62f9f550baf5} executeQuery: Code: 53. DB::Exception: Cannot convert string 'default.table_name' to type Int32: While processing n IN ('default.table_name') AS m: default expression and column type are incompatible. (TYPE_MISMATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:57012) (comment: 02433_default_expression_operator_in.sql) (in query: create table test (n int, m default in(n, 'default.table_name')) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a077ced 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:582: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391b308b 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391aa11e 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:671: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x00000000391b433e 7. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:130: std::vector> DB::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, bool) @ 0x0000000036a4137a 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:341: DB::makeExplicitSet(DB::ASTFunction const*, DB::ActionsDAG const&, std::shared_ptr, DB::PreparedSets&) @ 0x0000000036a046a2 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1504: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x0000000036a3a9a4 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:975: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a202de 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:732: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a1d275 12. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000369f7f95 13. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000036972ab7 14. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1859: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x00000000369a8a73 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1894: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x00000000369a9712 16. ./build_docker/./src/Storages/ColumnsDescription.cpp:1017: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x000000003c73559c 17. ./build_docker/./src/Storages/ColumnsDescription.cpp:1043: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000003c7368f3 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:670: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779acad 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:47:33.688181 [ 1429 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string 'default.table_name' to type Int32: While processing n IN ('default.table_name') AS m: default expression and column type are incompatible. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a077ced 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:582: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391b308b 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000391aa11e 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:671: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x00000000391b433e 7. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:130: std::vector> DB::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, bool) @ 0x0000000036a4137a 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:341: DB::makeExplicitSet(DB::ASTFunction const*, DB::ActionsDAG const&, std::shared_ptr, DB::PreparedSets&) @ 0x0000000036a046a2 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1504: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x0000000036a3a9a4 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:975: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a202de 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:732: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a1d275 12. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000369f7f95 13. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000036972ab7 14. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1859: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x00000000369a8a73 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1894: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x00000000369a9712 16. ./build_docker/./src/Storages/ColumnsDescription.cpp:1017: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x000000003c73559c 17. ./build_docker/./src/Storages/ColumnsDescription.cpp:1043: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000003c7368f3 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:670: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779acad 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:47:34.385558 [ 3076 ] {1398547f-4f07-4a0d-a609-bc05fc76d0b5} executeQuery: Code: 81. DB::Exception: Database test_2462 does not exist. (UNKNOWN_DATABASE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:57110) (comment: 01444_create_table_drop_database_race.sh) (in query: CREATE TABLE IF NOT EXISTS test_2462.t8562 (`x` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 44598, min_bytes_for_wide_part = 904724198, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 96, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 437988003, compact_parts_max_granules_to_buffer = 181, compact_parts_merge_max_bytes_to_prefetch_part = 25483296, merge_max_block_size = 19780, old_parts_lifetime = 100., prefer_fetch_merged_part_size_threshold = 4837764282, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 22166239, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 39771, primary_key_compress_block_size = 75898, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ce483 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:47:34.388867 [ 3076 ] {} TCPHandler: Code: 81. DB::Exception: Database test_2462 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ce483 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:47:34.398301 [ 423 ] {febdab92-952a-4b3f-b4fb-1994d66d01c6} executeQuery: Code: 81. DB::Exception: Database test_2462 does not exist. (UNKNOWN_DATABASE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:57126) (comment: 01444_create_table_drop_database_race.sh) (in query: CREATE TABLE IF NOT EXISTS test_2462.t22730 (`x` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 44598, min_bytes_for_wide_part = 904724198, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 96, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 437988003, compact_parts_max_granules_to_buffer = 181, compact_parts_merge_max_bytes_to_prefetch_part = 25483296, merge_max_block_size = 19780, old_parts_lifetime = 100., prefer_fetch_merged_part_size_threshold = 4837764282, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 22166239, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 39771, primary_key_compress_block_size = 75898, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ce483 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:47:34.404125 [ 423 ] {} TCPHandler: Code: 81. DB::Exception: Database test_2462 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ce483 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:47:35.926661 [ 423 ] {9883553a-c95f-4a05-b51f-ba7efc8293e0} executeQuery: Code: 81. DB::Exception: Database test_2462 does not exist. (UNKNOWN_DATABASE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:57212) (comment: 01444_create_table_drop_database_race.sh) (in query: CREATE TABLE IF NOT EXISTS test_2462.t18106 (`x` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 44598, min_bytes_for_wide_part = 904724198, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 96, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 437988003, compact_parts_max_granules_to_buffer = 181, compact_parts_merge_max_bytes_to_prefetch_part = 25483296, merge_max_block_size = 19780, old_parts_lifetime = 100., prefer_fetch_merged_part_size_threshold = 4837764282, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 22166239, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 39771, primary_key_compress_block_size = 75898, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ce483 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:47:35.930016 [ 423 ] {} TCPHandler: Code: 81. DB::Exception: Database test_2462 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ce483 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:47:35.970125 [ 1372 ] {f0a4ef10-8e1b-4d11-86f0-7316338f537e} executeQuery: Code: 81. DB::Exception: Database test_2462 does not exist. (UNKNOWN_DATABASE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:57230) (comment: 01444_create_table_drop_database_race.sh) (in query: CREATE TABLE IF NOT EXISTS test_2462.t23541 (`x` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 44598, min_bytes_for_wide_part = 904724198, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 96, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 437988003, compact_parts_max_granules_to_buffer = 181, compact_parts_merge_max_bytes_to_prefetch_part = 25483296, merge_max_block_size = 19780, old_parts_lifetime = 100., prefer_fetch_merged_part_size_threshold = 4837764282, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 22166239, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 39771, primary_key_compress_block_size = 75898, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ce483 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:47:35.973476 [ 1372 ] {} TCPHandler: Code: 81. DB::Exception: Database test_2462 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ce483 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:47:37.587945 [ 1429 ] {e9da9d45-9686-4bf0-9ede-5817967abdcb} executeQuery: Code: 36. DB::Exception: The function 'exponentialTimeDecayedAvg' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:57304) (comment: 03251_unaligned_window_function_state.sql) (in query: -- https://github.com/ClickHouse/ClickHouse/issues/70569 -- Reproduces UBSAN alert about misaligned address SELECT anyLast(id), anyLast(time), exponentialTimeDecayedAvg(10)(id, time) FROM values('id Int8, time DateTime', (1,1),(1,2),(2,3),(3,3),(3,5));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::WindowFunction::fail() const @ 0x000000004031ec8e 4. ./src/AggregateFunctions/WindowFunction.h:81: ? @ 0x000000004031b1e9 5. ./src/AggregateFunctions/IAggregateFunction.h:581: DB::IAggregateFunctionHelper::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x000000004031c4c4 6. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeWithoutKeyImpl(char*&, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, DB::Arena*, bool) const @ 0x0000000036a701ad 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1562: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000036a77b14 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000040084b96 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000040078368 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003f7213f8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002097cef4 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002098fd26 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002098fadf 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:47:37.593386 [ 1429 ] {} TCPHandler: Code: 36. DB::Exception: The function 'exponentialTimeDecayedAvg' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::WindowFunction::fail() const @ 0x000000004031ec8e 4. ./src/AggregateFunctions/WindowFunction.h:81: ? @ 0x000000004031b1e9 5. ./src/AggregateFunctions/IAggregateFunction.h:581: DB::IAggregateFunctionHelper::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x000000004031c4c4 6. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeWithoutKeyImpl(char*&, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, DB::Arena*, bool) const @ 0x0000000036a701ad 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1562: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000036a77b14 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000040084b96 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000040078368 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003f7213f8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002097cef4 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002098fd26 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002098fadf 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:47:39.882036 [ 3554 ] {8af90574-6c9c-465d-9c1f-b22227ec0a90} executeQuery: Code: 386. DB::Exception: There is no supertype for types String, UInt8 because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:55986) (comment: 02864_statistics_predicates.sql) (in query: SELECT count(*) FROM tab WHERE s = 7;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000034de3e22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000034df3acd 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000e4e2b6b 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e490364 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000035b12641 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000035b0e123 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:26: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x00000000400ed969 15. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000004078848e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x00000000385b7b64 17. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000038679845 18. ./build_docker/./src/Planner/Planner.cpp:1622: DB::Planner::buildPlanForQueryNode() @ 0x0000000038660dc5 19. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 23. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 24. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 30. ? @ 0x00007f583d9b1ac3 31. ? @ 0x00007f583da43850 2025.04.02 01:47:39.884908 [ 3554 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types String, UInt8 because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000034de3e22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000034df3acd 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000e4e2b6b 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e490364 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000035b12641 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000035b0e123 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:26: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x00000000400ed969 15. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000004078848e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x00000000385b7b64 17. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000038679845 18. ./build_docker/./src/Planner/Planner.cpp:1622: DB::Planner::buildPlanForQueryNode() @ 0x0000000038660dc5 19. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 23. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 24. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 30. ? @ 0x00007f583d9b1ac3 31. ? @ 0x00007f583da43850 2025.04.02 01:47:39.913059 [ 3554 ] {5b8dc776-562b-4ccd-a145-450a935838ab} executeQuery: Code: 386. DB::Exception: There is no supertype for types String, UInt8 because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:55986) (comment: 02864_statistics_predicates.sql) (in query: -- SELECT count(*) FROM tab WHERE s_tdigest = 7; -- not supported -- SELECT count(*) FROM tab WHERE s_minmax = 7; -- not supported SELECT count(*) FROM tab WHERE s_countmin = 7;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000034de3e22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000034df3acd 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000e4e2b6b 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e490364 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000035b12641 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000035b0e123 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:26: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x00000000400ed969 15. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000004078848e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x00000000385b7b64 17. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000038679845 18. ./build_docker/./src/Planner/Planner.cpp:1622: DB::Planner::buildPlanForQueryNode() @ 0x0000000038660dc5 19. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 23. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 24. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 30. ? @ 0x00007f583d9b1ac3 31. ? @ 0x00007f583da43850 2025.04.02 01:47:39.916456 [ 3554 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types String, UInt8 because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000034de3e22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000034df3acd 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000e4e2b6b 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e490364 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000035b12641 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000035b0e123 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:26: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x00000000400ed969 15. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000004078848e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x00000000385b7b64 17. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000038679845 18. ./build_docker/./src/Planner/Planner.cpp:1622: DB::Planner::buildPlanForQueryNode() @ 0x0000000038660dc5 19. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 23. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 24. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 30. ? @ 0x00007f583d9b1ac3 31. ? @ 0x00007f583da43850 2025.04.02 01:47:39.944524 [ 3554 ] {8adbe40c-b179-4040-967d-f6a73894ee27} executeQuery: Code: 386. DB::Exception: There is no supertype for types String, UInt8 because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:55986) (comment: 02864_statistics_predicates.sql) (in query: SELECT count(*) FROM tab WHERE s_uniq = 7;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000034de3e22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000034df3acd 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000e4e2b6b 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e490364 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000035b12641 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000035b0e123 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:26: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x00000000400ed969 15. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000004078848e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x00000000385b7b64 17. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000038679845 18. ./build_docker/./src/Planner/Planner.cpp:1622: DB::Planner::buildPlanForQueryNode() @ 0x0000000038660dc5 19. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 23. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 24. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 30. ? @ 0x00007f583d9b1ac3 31. ? @ 0x00007f583da43850 2025.04.02 01:47:39.947589 [ 3554 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types String, UInt8 because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000034de3e22 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000034df3acd 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000e4e2b6b 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e490364 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000035b12641 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000035b0e123 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:26: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x00000000400ed969 15. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000004078848e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x00000000385b7b64 17. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000038679845 18. ./build_docker/./src/Planner/Planner.cpp:1622: DB::Planner::buildPlanForQueryNode() @ 0x0000000038660dc5 19. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 23. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 24. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 30. ? @ 0x00007f583d9b1ac3 31. ? @ 0x00007f583da43850 2025.04.02 01:47:40.100191 [ 4457 ] {aad2e1fd-930d-446b-ac90-e744b70230d0} executeQuery: Code: 36. DB::Exception: Data type have to be specified for column `value` to add. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:57408) (comment: 01079_alter_default_zookeeper_long.sql) (in query: -- Cannot add column without type ALTER TABLE alter_default ADD COLUMN value DEFAULT '10';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1358: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003c6e9aba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775bdb6 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:47:40.102574 [ 4457 ] {} TCPHandler: Code: 36. DB::Exception: Data type have to be specified for column `value` to add. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1358: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003c6e9aba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775bdb6 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:47:41.924775 [ 4457 ] {08f945e8-0ddd-40a4-8ca5-69e131ce992c} executeQuery: Code: 6. DB::Exception: Cannot parse string 'q' as UInt8: syntax error at begin of string. Note: there are toUInt8OrZero and toUInt8OrNull functions, which returns zero/NULL instead of throwing exception.: While processing _CAST('q' AS bad_column_tmp_alter17931503208302390664, 'UInt8') AS bad_column: default expression and column type are incompatible. (CANNOT_PARSE_TEXT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:57408) (comment: 01079_alter_default_zookeeper_long.sql) (in query: ALTER TABLE alter_default ADD COLUMN bad_column UInt8 DEFAULT 'q';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000008c649a2 4. ./src/Functions/FunctionsConversion.h:1040: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt8, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000325be11c 5. ./src/Functions/FunctionsConversion.h:1578: bool DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000325a1187 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000032497579 7. ./src/Functions/FunctionsConversion.h:2511: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000032520269 8. ./src/Functions/FunctionsConversion.h:2292: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003251ee62 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000031eab4c9 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 16. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 18. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 22. ./build_docker/./src/Interpreters/ActionsDAG.cpp:345: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x0000000035aec54e 23. ./build_docker/./src/Interpreters/ActionsDAG.cpp:262: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000035ae9cd1 24. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:673: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000036a1b643 25. ./src/Interpreters/ActionsVisitor.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000036a45c93 26. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1342: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a21e35 27. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:732: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a1d275 28. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000369f7f95 29. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000036972ab7 30. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1859: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x00000000369a8a73 31. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1894: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x00000000369a9712 2025.04.02 01:47:41.927841 [ 4457 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'q' as UInt8: syntax error at begin of string. Note: there are toUInt8OrZero and toUInt8OrNull functions, which returns zero/NULL instead of throwing exception.: While processing _CAST('q' AS bad_column_tmp_alter17931503208302390664, 'UInt8') AS bad_column: default expression and column type are incompatible. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000008c649a2 4. ./src/Functions/FunctionsConversion.h:1040: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt8, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000325be11c 5. ./src/Functions/FunctionsConversion.h:1578: bool DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000325a1187 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000032497579 7. ./src/Functions/FunctionsConversion.h:2511: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000032520269 8. ./src/Functions/FunctionsConversion.h:2292: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003251ee62 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000031eab4c9 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 16. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 18. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 22. ./build_docker/./src/Interpreters/ActionsDAG.cpp:345: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x0000000035aec54e 23. ./build_docker/./src/Interpreters/ActionsDAG.cpp:262: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000035ae9cd1 24. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:673: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000036a1b643 25. ./src/Interpreters/ActionsVisitor.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000036a45c93 26. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1342: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a21e35 27. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:732: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a1d275 28. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000369f7f95 29. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000036972ab7 30. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1859: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x00000000369a8a73 31. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1894: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x00000000369a9712 2025.04.02 01:47:43.554396 [ 4457 ] {038c02e7-c291-4223-9899-da0c2e687e88} executeQuery: Code: 41. DB::Exception: Cannot parse DateTime: Cannot parse DateTime from String: While processing _CAST('0' AS other_date_tmp_alter17397710176944499509, 'DateTime') AS other_date: default expression and column type are incompatible. (CANNOT_PARSE_DATETIME) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:57408) (comment: 01079_alter_default_zookeeper_long.sql) (in query: ALTER TABLE alter_default MODIFY COLUMN other_date DateTime;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/IO/ReadHelpers.cpp:1571: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000002087b10a 5. ./src/IO/ReadHelpers.h:1101: void DB::readDateTimeTextImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x0000000027db3fdd 6. ./src/IO/ReadHelpers.h:1204: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000328e3546 7. ./src/Functions/FunctionsConversion.h:1578: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000328b76e7 8. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000324fb80b 9. ./src/Functions/FunctionsConversion.h:2511: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000032568429 10. ./src/Functions/FunctionsConversion.h:2292: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000032566dc2 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 15. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 16. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000031eab4c9 17. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 18. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 20. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 22. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 23. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 24. ./build_docker/./src/Interpreters/ActionsDAG.cpp:345: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x0000000035aec54e 25. ./build_docker/./src/Interpreters/ActionsDAG.cpp:262: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000035ae9cd1 26. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:673: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000036a1b643 27. ./src/Interpreters/ActionsVisitor.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000036a45c93 28. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1342: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a21e35 29. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:732: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a1d275 30. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000369f7f95 31. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000036972ab7 2025.04.02 01:47:43.557042 [ 4457 ] {} TCPHandler: Code: 41. DB::Exception: Cannot parse DateTime: Cannot parse DateTime from String: While processing _CAST('0' AS other_date_tmp_alter17397710176944499509, 'DateTime') AS other_date: default expression and column type are incompatible. (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/IO/ReadHelpers.cpp:1571: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000002087b10a 5. ./src/IO/ReadHelpers.h:1101: void DB::readDateTimeTextImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x0000000027db3fdd 6. ./src/IO/ReadHelpers.h:1204: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000328e3546 7. ./src/Functions/FunctionsConversion.h:1578: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000328b76e7 8. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000324fb80b 9. ./src/Functions/FunctionsConversion.h:2511: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000032568429 10. ./src/Functions/FunctionsConversion.h:2292: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000032566dc2 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 15. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 16. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000031eab4c9 17. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 18. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008928022 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 20. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 22. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 23. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 24. ./build_docker/./src/Interpreters/ActionsDAG.cpp:345: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x0000000035aec54e 25. ./build_docker/./src/Interpreters/ActionsDAG.cpp:262: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000035ae9cd1 26. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:673: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000036a1b643 27. ./src/Interpreters/ActionsVisitor.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000036a45c93 28. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1342: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a21e35 29. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:732: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a1d275 30. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000369f7f95 31. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000036972ab7 2025.04.02 01:47:57.403940 [ 3817 ] {d1afba42-684b-4816-af30-7e9c15d91327} executeQuery: Code: 36. DB::Exception: TTL expression toDate('2020-01-01') does not depend on any of the columns of the table. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:59238) (comment: 01652_ttl_old_syntax.sql) (in query: ALTER TABLE ttl_old_syntax MODIFY TTL toDate('2020-01-01');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ac716ea 4. ./build_docker/./src/Storages/TTLDescription.cpp:73: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x000000003d39275a 5. ./build_docker/./src/Storages/TTLDescription.cpp:405: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x000000003d395aa6 6. ./build_docker/./src/Storages/AlterCommands.cpp:809: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003c6c2935 7. ./build_docker/./src/Storages/AlterCommands.cpp:1180: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003c6d7650 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3469: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003dea80a0 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:218: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775be7b 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 20. ? @ 0x00007f583d9b1ac3 21. ? @ 0x00007f583da43850 2025.04.02 01:47:57.406876 [ 3817 ] {} TCPHandler: Code: 36. DB::Exception: TTL expression toDate('2020-01-01') does not depend on any of the columns of the table. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ac716ea 4. ./build_docker/./src/Storages/TTLDescription.cpp:73: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x000000003d39275a 5. ./build_docker/./src/Storages/TTLDescription.cpp:405: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x000000003d395aa6 6. ./build_docker/./src/Storages/AlterCommands.cpp:809: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003c6c2935 7. ./build_docker/./src/Storages/AlterCommands.cpp:1180: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003c6d7650 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3469: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003dea80a0 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:218: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775be7b 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 20. ? @ 0x00007f583d9b1ac3 21. ? @ 0x00007f583da43850 2025.04.02 01:48:01.440684 [ 1424 ] {0115dbc1-e826-4be6-a0bc-cbf3d9cab922} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate'. Expected 1 argument, got 0 arguments: In scope SELECT YYYYMMDDToDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37012) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000031c40977 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3be33 5. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151703c7 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:48:01.443410 [ 1424 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate'. Expected 1 argument, got 0 arguments: In scope SELECT YYYYMMDDToDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000031c40977 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3be33 5. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151703c7 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:48:02.631841 [ 1424 ] {f41cb95d-1e4b-4b20-80a6-b916a744dd5b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: Date: In scope SELECT YYYYMMDDToDate(toDate('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37012) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate(toDate('2023-09-11'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151703c7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:48:02.647996 [ 1424 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: Date: In scope SELECT YYYYMMDDToDate(toDate('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151703c7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:48:02.679865 [ 1424 ] {23993313-996e-42e3-8c64-ba3e968b380e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: Date32: In scope SELECT YYYYMMDDToDate(toDate32('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37012) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate(toDate32('2023-09-11'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151703c7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:48:02.683436 [ 1424 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: Date32: In scope SELECT YYYYMMDDToDate(toDate32('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151703c7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:48:02.717493 [ 1424 ] {7d1c47dc-de96-47eb-b6a2-99602195b29e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: DateTime: In scope SELECT YYYYMMDDToDate(toDateTime('2023-09-11 12:18:00')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37012) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate(toDateTime('2023-09-11 12:18:00'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151703c7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:48:02.732946 [ 1424 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: DateTime: In scope SELECT YYYYMMDDToDate(toDateTime('2023-09-11 12:18:00')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151703c7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:48:02.756998 [ 1424 ] {a6017064-90bf-4956-9028-003dd1556b09} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: DateTime64(3): In scope SELECT YYYYMMDDToDate(toDateTime64('2023-09-11 12:18:00', 3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37012) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate(toDateTime64('2023-09-11 12:18:00', 3));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151703c7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:48:02.759963 [ 1424 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: DateTime64(3): In scope SELECT YYYYMMDDToDate(toDateTime64('2023-09-11 12:18:00', 3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151703c7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:48:02.785447 [ 1424 ] {da6a33a8-0ea7-41ac-9aa2-520588a1a6b0} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: String: In scope SELECT YYYYMMDDToDate('2023-09-11'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37012) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate('2023-09-11');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151703c7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:48:02.801065 [ 1424 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: String: In scope SELECT YYYYMMDDToDate('2023-09-11'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151703c7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:48:02.816657 [ 1424 ] {36799c5b-4922-4bfe-a1e6-43288f8ccc4d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate'. Expected 1 argument, got 3 arguments: In scope SELECT YYYYMMDDToDate(2023, 9, 11). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37012) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate(2023, 09, 11);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000031c40977 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3be33 5. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151703c7 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:48:02.833245 [ 1424 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate'. Expected 1 argument, got 3 arguments: In scope SELECT YYYYMMDDToDate(2023, 9, 11). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000031c40977 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3be33 5. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151703c7 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:48:02.863941 [ 1424 ] {ae99ee7f-3675-449c-8dce-3b806fbc2a68} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate'. Expected 1 argument, got 2 arguments: In scope SELECT YYYYMMDDToDate(2023, 110). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37012) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate(2023, 110);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000031c40977 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3be33 5. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151703c7 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:48:02.881436 [ 1424 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate'. Expected 1 argument, got 2 arguments: In scope SELECT YYYYMMDDToDate(2023, 110). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000031c40977 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3be33 5. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151703c7 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:48:03.290179 [ 1429 ] {8719a78d-1a4a-414c-8c57-57d71232ce12} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37122) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:03.293847 [ 1429 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:03.482160 [ 3300 ] {76b28c3a-47de-43df-a474-aefe1a441343} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37134) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:03.486480 [ 3300 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:03.539590 [ 6494 ] {93fa5487-d09b-4978-904d-85fe28be5394} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37250) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:03.543164 [ 6494 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:04.035460 [ 6495 ] {} TCPHandler: Code: 394. DB::Exception: Query '40cc249f-76ee-4818-9878-8d667d12c1ec' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1432: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003928019d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 6. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 7. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 13. ? @ 0x00007f583d9b1ac3 14. ? @ 0x00007f583da43850 2025.04.02 01:48:04.045669 [ 6485 ] {} TCPHandler: Code: 394. DB::Exception: Query '978bfe49-d124-4ea8-bb75-cdb503913ffa' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1432: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003928019d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 6. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 7. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 13. ? @ 0x00007f583d9b1ac3 14. ? @ 0x00007f583da43850 2025.04.02 01:48:04.257801 [ 6493 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762b58 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:440: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000039414e06 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:223: DB::InterpreterKillQueryQuery::execute() @ 0x00000000393feea2 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:48:04.296732 [ 3554 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762b58 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:440: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000039414e06 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:223: DB::InterpreterKillQueryQuery::execute() @ 0x00000000393feea2 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:48:04.336524 [ 6500 ] {374aa499-8718-44a9-b8fe-e6b311038016} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37292) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003f75bb6f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003f75dc4b 11. ./build_docker/./src/Server/TCPHandler.cpp:1231: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003f45122b 12. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000003f42c464 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 19. ? @ 0x00007f583d9b1ac3 20. ? @ 0x00007f583da43850 2025.04.02 01:48:04.350276 [ 6500 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003f75bb6f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003f75dc4b 11. ./build_docker/./src/Server/TCPHandler.cpp:1231: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003f45122b 12. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000003f42c464 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 19. ? @ 0x00007f583d9b1ac3 20. ? @ 0x00007f583da43850 2025.04.02 01:48:04.383208 [ 6498 ] {a6b6f6e9-3e02-4158-88d2-921d1cebe018} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37276) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:04.387502 [ 6498 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:05.169874 [ 3817 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762b58 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:440: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000039414e06 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:223: DB::InterpreterKillQueryQuery::execute() @ 0x00000000393feea2 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:48:05.711685 [ 1424 ] {807a6d23-0813-40e3-bb0d-31b88e51deca} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDToDate must be finite: In scope SELECT YYYYMMDDToDate(nan). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37012) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate(NaN);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001516fc82 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 27. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 28. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 2025.04.02 01:48:05.720866 [ 1424 ] {} TCPHandler: Code: 36. DB::Exception: Argument for function YYYYMMDDToDate must be finite: In scope SELECT YYYYMMDDToDate(nan). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001516fc82 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 27. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 28. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 2025.04.02 01:48:05.748235 [ 1424 ] {3a7c8ec6-5192-4874-8253-e0dc2d52d8c8} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDToDate must be finite: In scope SELECT YYYYMMDDToDate(inf). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37012) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate(Inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001516fc82 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 27. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 28. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 2025.04.02 01:48:05.751303 [ 1424 ] {} TCPHandler: Code: 36. DB::Exception: Argument for function YYYYMMDDToDate must be finite: In scope SELECT YYYYMMDDToDate(inf). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001516fc82 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 27. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 28. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 2025.04.02 01:48:05.781633 [ 1424 ] {d5277419-3135-4f0e-b6cd-9de044e1e1c1} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDToDate must be finite: In scope SELECT YYYYMMDDToDate(-inf). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37012) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate(-Inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001516fc82 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 27. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 28. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 2025.04.02 01:48:05.784846 [ 1424 ] {} TCPHandler: Code: 36. DB::Exception: Argument for function YYYYMMDDToDate must be finite: In scope SELECT YYYYMMDDToDate(-inf). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001516fc82 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 27. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 28. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 2025.04.02 01:48:05.815981 [ 6491 ] {} TCPHandler: Code: 394. DB::Exception: Query '278abe93-c0ac-48ac-a423-98763cbbf30e' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1432: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003928019d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 6. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 7. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 13. ? @ 0x00007f583d9b1ac3 14. ? @ 0x00007f583da43850 2025.04.02 01:48:06.015419 [ 6494 ] {} TCPHandler: Code: 394. DB::Exception: Query '83631e89-36e7-4a37-9c7f-63a1209345f5' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1432: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003928019d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 6. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 7. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 13. ? @ 0x00007f583d9b1ac3 14. ? @ 0x00007f583da43850 2025.04.02 01:48:06.449021 [ 3560 ] {83d8a1e5-acb6-4f29-bb61-519df4cca942} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37630) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:06.465608 [ 3560 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:06.542764 [ 3817 ] {382f07a7-42c5-4ac4-bf6a-b151f2c03945} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37702) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:06.548813 [ 3161 ] {1715255a-44bd-48ab-a289-84d47f6472dd} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37620) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:06.552382 [ 3161 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:06.564452 [ 3817 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:07.072252 [ 6485 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762b58 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:440: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000039414e06 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:223: DB::InterpreterKillQueryQuery::execute() @ 0x00000000393feea2 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:48:07.449672 [ 6498 ] {54fb0da9-8a5a-466c-90ff-5f81a85faefe} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37758) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:07.457364 [ 6498 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:07.604137 [ 6484 ] {8712d85e-c6f0-4b0c-b34d-93e5ec108fca} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37790) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:07.608025 [ 6484 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:07.774449 [ 3093 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:175: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d96f 9. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762e32 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:440: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000039414e06 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:223: DB::InterpreterKillQueryQuery::execute() @ 0x00000000393feea2 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:48:07.774482 [ 3076 ] {a4a801a9-f736-4f61-b016-3bfa639be9e9} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37822) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:07.778397 [ 3076 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:08.504292 [ 3161 ] {101ccbea-2128-44e5-b522-e98b955d795e} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37914) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003f75bb6f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003f75dc4b 11. ./build_docker/./src/Server/TCPHandler.cpp:1231: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003f45122b 12. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000003f42c464 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 19. ? @ 0x00007f583d9b1ac3 20. ? @ 0x00007f583da43850 2025.04.02 01:48:08.506806 [ 6484 ] {} TCPHandler: Code: 394. DB::Exception: Query 'abeb5c23-b541-4dbe-8acb-5cc0c0be03a2' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1432: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003928019d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 6. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 7. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 13. ? @ 0x00007f583d9b1ac3 14. ? @ 0x00007f583da43850 2025.04.02 01:48:08.523246 [ 3161 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003f75bb6f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003f75dc4b 11. ./build_docker/./src/Server/TCPHandler.cpp:1231: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003f45122b 12. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000003f42c464 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 19. ? @ 0x00007f583d9b1ac3 20. ? @ 0x00007f583da43850 2025.04.02 01:48:08.644129 [ 1424 ] {a1df7b0d-6008-4ddd-b751-c8e68f602681} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate32'. Expected: Number, got: Date: In scope SELECT YYYYMMDDToDate32(toDate('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37012) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate32(toDate('2023-09-11'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151727e7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:48:08.647654 [ 1424 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate32'. Expected: Number, got: Date: In scope SELECT YYYYMMDDToDate32(toDate('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151727e7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:48:08.684490 [ 1424 ] {7b74f22d-5cbf-422b-870a-b4bc8167a747} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate32'. Expected: Number, got: Date32: In scope SELECT YYYYMMDDToDate32(toDate32('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37012) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate32(toDate32('2023-09-11'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151727e7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:48:08.704171 [ 1424 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate32'. Expected: Number, got: Date32: In scope SELECT YYYYMMDDToDate32(toDate32('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151727e7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:48:08.739183 [ 1424 ] {e0969950-f7b4-4837-a5d3-5ddce23f76f6} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate32'. Expected: Number, got: DateTime: In scope SELECT YYYYMMDDToDate32(toDateTime('2023-09-11 12:18:00')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37012) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate32(toDateTime('2023-09-11 12:18:00'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151727e7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:48:08.741982 [ 1424 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate32'. Expected: Number, got: DateTime: In scope SELECT YYYYMMDDToDate32(toDateTime('2023-09-11 12:18:00')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151727e7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:48:08.768485 [ 1424 ] {102cfd72-7d1a-4ae1-a163-4b3a8ebf5e3b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate32'. Expected: Number, got: DateTime64(3): In scope SELECT YYYYMMDDToDate32(toDateTime64('2023-09-11 12:18:00', 3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37012) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate32(toDateTime64('2023-09-11 12:18:00', 3));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151727e7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:48:08.789441 [ 1424 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate32'. Expected: Number, got: DateTime64(3): In scope SELECT YYYYMMDDToDate32(toDateTime64('2023-09-11 12:18:00', 3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151727e7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:48:08.819361 [ 1424 ] {ed019a52-7bad-4f70-8b38-892beae08084} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate32'. Expected: Number, got: String: In scope SELECT YYYYMMDDToDate32('2023-09-11'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37012) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate32('2023-09-11');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151727e7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:48:08.829975 [ 1424 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate32'. Expected: Number, got: String: In scope SELECT YYYYMMDDToDate32('2023-09-11'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151727e7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:48:08.852549 [ 6500 ] {1d94165d-65c7-4314-bd72-12f795973aff} executeQuery: Code: 128. DB::Exception: Array size -231 cannot be negative: while executing function arrayWithConstant: In scope SELECT arrayWithConstant(-231.37104, -138). (TOO_LARGE_ARRAY_SIZE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37786) (comment: 00842_array_with_constant_overflow.sql) (in query: SELECT arrayWithConstant(-231.37104, -138);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, long&, String&&) @ 0x000000001827078d 4. DB::FunctionArrayWithConstant::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f6843a3 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 27. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 28. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 2025.04.02 01:48:08.856564 [ 6500 ] {} TCPHandler: Code: 128. DB::Exception: Array size -231 cannot be negative: while executing function arrayWithConstant: In scope SELECT arrayWithConstant(-231.37104, -138). (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, long&, String&&) @ 0x000000001827078d 4. DB::FunctionArrayWithConstant::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f6843a3 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 27. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 28. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 2025.04.02 01:48:09.120610 [ 3093 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762b58 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:440: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000039414e06 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:223: DB::InterpreterKillQueryQuery::execute() @ 0x00000000393feea2 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:48:09.138186 [ 3161 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762b58 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:440: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000039414e06 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:223: DB::InterpreterKillQueryQuery::execute() @ 0x00000000393feea2 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:48:09.185035 [ 6495 ] {fde63710-4c85-42ba-aa2e-f3de0795325f} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37936) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:09.189111 [ 6495 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:09.786140 [ 1424 ] {8ac17579-fa4a-4e7b-b099-52b2432e4709} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate32'. Expected 1 argument, got 3 arguments: In scope SELECT YYYYMMDDToDate32(2023, 9, 11). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37012) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate32(2023, 09, 11);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000031c40977 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3be33 5. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151727e7 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:48:09.800176 [ 1424 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate32'. Expected 1 argument, got 3 arguments: In scope SELECT YYYYMMDDToDate32(2023, 9, 11). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000031c40977 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3be33 5. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151727e7 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:48:09.834374 [ 1424 ] {2f3e0d76-e46e-4faf-adb3-e788701baf50} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate32'. Expected 1 argument, got 2 arguments: In scope SELECT YYYYMMDDToDate32(2023, 110). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37012) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate32(2023, 110);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000031c40977 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3be33 5. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151727e7 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:48:09.839629 [ 1424 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate32'. Expected 1 argument, got 2 arguments: In scope SELECT YYYYMMDDToDate32(2023, 110). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000031c40977 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3be33 5. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151727e7 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:48:10.061237 [ 2377 ] {1e7c52cd-8e43-427b-8131-4bbe65cb089f} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48028) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003f75bb6f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003f75dc4b 11. ./build_docker/./src/Server/TCPHandler.cpp:1231: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003f45122b 12. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000003f42c464 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 19. ? @ 0x00007f583d9b1ac3 20. ? @ 0x00007f583da43850 2025.04.02 01:48:10.077235 [ 2377 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003f75bb6f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003f75dc4b 11. ./build_docker/./src/Server/TCPHandler.cpp:1231: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003f45122b 12. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000003f42c464 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 19. ? @ 0x00007f583d9b1ac3 20. ? @ 0x00007f583da43850 2025.04.02 01:48:10.230347 [ 3093 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762b58 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:440: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000039414e06 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:223: DB::InterpreterKillQueryQuery::execute() @ 0x00000000393feea2 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:48:11.524719 [ 6498 ] {} TCPHandler: Code: 394. DB::Exception: Query 'cbcc7607-1349-452d-8aec-965b37a86780' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1432: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003928019d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 6. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 7. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 13. ? @ 0x00007f583d9b1ac3 14. ? @ 0x00007f583da43850 2025.04.02 01:48:12.435318 [ 1424 ] {5b3fb3ab-6cd4-4969-ab2f-ebc17ce2eabc} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDToDate32 must be finite: In scope SELECT YYYYMMDDToDate32(nan). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37012) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate32(NaN);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000151720a2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 27. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 28. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 2025.04.02 01:48:12.439008 [ 1424 ] {} TCPHandler: Code: 36. DB::Exception: Argument for function YYYYMMDDToDate32 must be finite: In scope SELECT YYYYMMDDToDate32(nan). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000151720a2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 27. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 28. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 2025.04.02 01:48:12.457266 [ 1424 ] {ebd9316a-68bc-4d5b-b0eb-087e89d06be4} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDToDate32 must be finite: In scope SELECT YYYYMMDDToDate32(inf). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37012) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate32(Inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000151720a2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 27. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 28. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 2025.04.02 01:48:12.460317 [ 1424 ] {} TCPHandler: Code: 36. DB::Exception: Argument for function YYYYMMDDToDate32 must be finite: In scope SELECT YYYYMMDDToDate32(inf). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000151720a2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 27. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 28. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 2025.04.02 01:48:12.478524 [ 1424 ] {4d3448b2-2cb2-4154-a883-cb34b7997e53} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDToDate32 must be finite: In scope SELECT YYYYMMDDToDate32(-inf). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37012) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate32(-Inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000151720a2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 27. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 28. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 2025.04.02 01:48:12.481532 [ 1424 ] {} TCPHandler: Code: 36. DB::Exception: Argument for function YYYYMMDDToDate32 must be finite: In scope SELECT YYYYMMDDToDate32(-inf). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000151720a2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 27. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 28. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 2025.04.02 01:48:12.824715 [ 6488 ] {6f3b8a27-07be-4ee6-8a9e-695b0e0227b0} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48314) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:12.828629 [ 6488 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:12.879547 [ 3554 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762b58 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:440: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000039414e06 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:223: DB::InterpreterKillQueryQuery::execute() @ 0x00000000393feea2 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:48:13.092820 [ 3300 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762b58 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:440: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000039414e06 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:223: DB::InterpreterKillQueryQuery::execute() @ 0x00000000393feea2 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:48:13.866999 [ 1429 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762b58 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:440: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000039414e06 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:223: DB::InterpreterKillQueryQuery::execute() @ 0x00000000393feea2 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:48:14.239643 [ 1429 ] {bd70724f-c2db-46ce-b432-65999ed155da} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48570) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:14.243782 [ 1429 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:15.206315 [ 1424 ] {0c184237-60d5-4d57-8e84-8ca5cd5a8e6b} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48670) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003f75bb6f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003f75dc4b 11. ./build_docker/./src/Server/TCPHandler.cpp:1231: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003f45122b 12. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000003f42c464 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 19. ? @ 0x00007f583d9b1ac3 20. ? @ 0x00007f583da43850 2025.04.02 01:48:15.225326 [ 1424 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003f75bb6f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003f75dc4b 11. ./build_docker/./src/Server/TCPHandler.cpp:1231: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003f45122b 12. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000003f42c464 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 19. ? @ 0x00007f583d9b1ac3 20. ? @ 0x00007f583da43850 2025.04.02 01:48:15.234176 [ 2377 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762b58 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:440: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000039414e06 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:223: DB::InterpreterKillQueryQuery::execute() @ 0x00000000393feea2 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:48:16.022076 [ 1429 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762b58 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:440: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000039414e06 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:223: DB::InterpreterKillQueryQuery::execute() @ 0x00000000393feea2 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:48:16.095445 [ 6495 ] {19b5dd1a-10a1-4e50-9d17-659ecb4354b1} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48792) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:16.099035 [ 6495 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:17.742551 [ 3817 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762b58 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:440: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000039414e06 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:223: DB::InterpreterKillQueryQuery::execute() @ 0x00000000393feea2 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:48:18.633717 [ 3817 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762b58 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:440: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000039414e06 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:223: DB::InterpreterKillQueryQuery::execute() @ 0x00000000393feea2 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:48:18.915965 [ 6493 ] {3d0a1bb4-307a-4471-a1fb-6c7750bb9307} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:49200) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:18.926591 [ 6493 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:19.049269 [ 423 ] {5dff1f59-2fa4-44a3-b0dc-75a6e570166f} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:49272) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003f75bb6f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003f75dc4b 11. ./build_docker/./src/Server/TCPHandler.cpp:1231: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003f45122b 12. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000003f42c464 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 19. ? @ 0x00007f583d9b1ac3 20. ? @ 0x00007f583da43850 2025.04.02 01:48:19.071679 [ 423 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003f75bb6f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003f75dc4b 11. ./build_docker/./src/Server/TCPHandler.cpp:1231: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003f45122b 12. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000003f42c464 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 19. ? @ 0x00007f583d9b1ac3 20. ? @ 0x00007f583da43850 2025.04.02 01:48:19.982797 [ 3300 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762b58 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:440: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000039414e06 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:223: DB::InterpreterKillQueryQuery::execute() @ 0x00000000393feea2 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:48:20.334524 [ 6500 ] {01b8f040-45bb-4660-969b-8c9d1cefc683} executeQuery: Code: 36. DB::Exception: Argument 'format/NOSIGN' must be a literal with type String, got Array. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:49086) (comment: 02245_s3_schema_desc.sql) (in query: SELECT * FROM s3(decodeURLComponent(NULL), [NULL]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl::type, std::type_identity>>::type, std::type_identity>>::type>, String const&, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x000000003d3e5817 4. ./build_docker/./src/Storages/checkAndGetLiteralArgument.cpp:39: String DB::checkAndGetLiteralArgument(DB::ASTLiteral const&, String const&) @ 0x000000003d3e3a23 5. ./build_docker/./src/Storages/checkAndGetLiteralArgument.cpp:22: String DB::checkAndGetLiteralArgument(std::shared_ptr const&, String const&) @ 0x000000003d3e2f39 6. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:213: DB::StorageS3Configuration::fromAST(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x000000003332466a 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:568: DB::StorageObjectStorage::Configuration::initialize(DB::StorageObjectStorage::Configuration&, absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool, std::unique_ptr>) @ 0x00000000330ec3ca 8. ./src/TableFunctions/TableFunctionObjectStorage.h:133: DB::TableFunctionObjectStorage::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x00000000274e8f1e 9. ./build_docker/./src/TableFunctions/TableFunctionObjectStorageClusterFallback.cpp:98: DB::TableFunctionObjectStorageClusterFallback>::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x00000000275ec22f 10. ./build_docker/./src/TableFunctions/TableFunctionObjectStorage.cpp:76: DB::TableFunctionObjectStorage::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000274ec637 11. ./src/TableFunctions/ITableFunctionCluster.h:42: DB::ITableFunctionCluster>::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000275b42e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4813: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000035d4abb8 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5295: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000035ddf701 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5552: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24c93 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:48:20.349615 [ 6500 ] {} TCPHandler: Code: 36. DB::Exception: Argument 'format/NOSIGN' must be a literal with type String, got Array. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl::type, std::type_identity>>::type, std::type_identity>>::type>, String const&, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x000000003d3e5817 4. ./build_docker/./src/Storages/checkAndGetLiteralArgument.cpp:39: String DB::checkAndGetLiteralArgument(DB::ASTLiteral const&, String const&) @ 0x000000003d3e3a23 5. ./build_docker/./src/Storages/checkAndGetLiteralArgument.cpp:22: String DB::checkAndGetLiteralArgument(std::shared_ptr const&, String const&) @ 0x000000003d3e2f39 6. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:213: DB::StorageS3Configuration::fromAST(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x000000003332466a 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:568: DB::StorageObjectStorage::Configuration::initialize(DB::StorageObjectStorage::Configuration&, absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool, std::unique_ptr>) @ 0x00000000330ec3ca 8. ./src/TableFunctions/TableFunctionObjectStorage.h:133: DB::TableFunctionObjectStorage::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x00000000274e8f1e 9. ./build_docker/./src/TableFunctions/TableFunctionObjectStorageClusterFallback.cpp:98: DB::TableFunctionObjectStorageClusterFallback>::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x00000000275ec22f 10. ./build_docker/./src/TableFunctions/TableFunctionObjectStorage.cpp:76: DB::TableFunctionObjectStorage::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000274ec637 11. ./src/TableFunctions/ITableFunctionCluster.h:42: DB::ITableFunctionCluster>::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000275b42e6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4813: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000035d4abb8 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5295: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000035ddf701 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5552: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24c93 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:48:20.628018 [ 6498 ] {7cc43257-0ff9-4615-b69b-1576e060bc0e} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42578) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003f75bb6f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003f75dc4b 11. ./build_docker/./src/Server/TCPHandler.cpp:1231: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003f45122b 12. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000003f42c464 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 19. ? @ 0x00007f583d9b1ac3 20. ? @ 0x00007f583da43850 2025.04.02 01:48:20.636822 [ 6498 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003f75bb6f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003f75dc4b 11. ./build_docker/./src/Server/TCPHandler.cpp:1231: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003f45122b 12. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000003f42c464 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 19. ? @ 0x00007f583d9b1ac3 20. ? @ 0x00007f583da43850 2025.04.02 01:48:20.865448 [ 6489 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762b58 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:440: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000039414e06 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:223: DB::InterpreterKillQueryQuery::execute() @ 0x00000000393feea2 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:48:20.873354 [ 6491 ] {f0029465-80a4-4c94-b603-39eac823bfd0} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42588) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:20.877230 [ 6491 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:20.957471 [ 6494 ] {9646fe50-468b-4197-af40-591fa29c0eb0} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42642) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:20.961364 [ 6494 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:21.036871 [ 6493 ] {9137edb5-fa77-4845-936f-d09c0f49cd0d} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42626) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:21.040630 [ 6493 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:22.024075 [ 6500 ] {} TCPHandler: Code: 394. DB::Exception: Query '174d9724-5a2b-4c38-aae3-255c48494d8a' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1432: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003928019d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 6. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 7. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 13. ? @ 0x00007f583d9b1ac3 14. ? @ 0x00007f583da43850 2025.04.02 01:48:22.943338 [ 1429 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:175: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d96f 9. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762e32 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:440: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000039414e06 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:223: DB::InterpreterKillQueryQuery::execute() @ 0x00000000393feea2 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:48:22.976128 [ 423 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762b58 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:440: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000039414e06 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:223: DB::InterpreterKillQueryQuery::execute() @ 0x00000000393feea2 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:48:23.040451 [ 6493 ] {988677a0-6414-4ded-ba01-1c165c3f4ad6} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42858) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:23.044013 [ 6493 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:23.085740 [ 6498 ] {f73bbc5b-7a0b-4559-ad8b-922d567ab1a7} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42880) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:23.114129 [ 6498 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:23.736812 [ 6484 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762b58 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:440: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000039414e06 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:223: DB::InterpreterKillQueryQuery::execute() @ 0x00000000393feea2 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:48:25.218383 [ 6491 ] {3abe9203-88e8-40b5-a05f-f4fd0b24576e} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43202) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003f75bb6f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003f75dc4b 11. ./build_docker/./src/Server/TCPHandler.cpp:1231: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003f45122b 12. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000003f42c464 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 19. ? @ 0x00007f583d9b1ac3 20. ? @ 0x00007f583da43850 2025.04.02 01:48:25.224419 [ 6491 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003f75bb6f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003f75dc4b 11. ./build_docker/./src/Server/TCPHandler.cpp:1231: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003f45122b 12. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000003f42c464 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 19. ? @ 0x00007f583d9b1ac3 20. ? @ 0x00007f583da43850 2025.04.02 01:48:25.680253 [ 6498 ] {} TCPHandler: Code: 394. DB::Exception: Query 'e32a02d5-d0ac-4782-9219-9355a1eddab4' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1432: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003928019d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 6. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 7. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 13. ? @ 0x00007f583d9b1ac3 14. ? @ 0x00007f583da43850 2025.04.02 01:48:25.696915 [ 6484 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:175: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d96f 9. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762e32 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:440: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000039414e06 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:223: DB::InterpreterKillQueryQuery::execute() @ 0x00000000393feea2 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:48:25.708825 [ 3093 ] {5359ee9b-8bfa-4e57-a7f4-64dc1cde0057} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43298) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:25.721456 [ 3093 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:25.933060 [ 2377 ] {f4dfa148-1fc5-4a9c-9123-2ec62e2a4cbe} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43254) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:25.954606 [ 2377 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:26.867213 [ 6485 ] {981f3266-508b-4d19-b29b-fb16d0c28908} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43452) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003f75bb6f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003f75dc4b 11. ./build_docker/./src/Server/TCPHandler.cpp:1231: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003f45122b 12. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000003f42c464 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 19. ? @ 0x00007f583d9b1ac3 20. ? @ 0x00007f583da43850 2025.04.02 01:48:26.885732 [ 6485 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003f75bb6f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003f75dc4b 11. ./build_docker/./src/Server/TCPHandler.cpp:1231: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003f45122b 12. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000003f42c464 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 19. ? @ 0x00007f583d9b1ac3 20. ? @ 0x00007f583da43850 2025.04.02 01:48:27.282921 [ 6489 ] {ee920ce4-9459-4639-8331-2c19ffa82584} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43442) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:27.291257 [ 6489 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:27.358731 [ 4457 ] {6be9c7d3-8924-4c10-8773-fb0103e05558} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43486) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:27.362765 [ 4457 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:27.757743 [ 6498 ] {20090cbf-61b2-4355-ba15-632f4c2a8396} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43586) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:27.823038 [ 1429 ] {bc657d9a-7a42-497c-8a18-047d2d2072d2} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43518) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:28.048242 [ 6498 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:28.053019 [ 1429 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:28.064761 [ 423 ] {3c2446d0-f574-4d1f-a37a-c6fb9c859a64} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43512) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:28.074375 [ 423 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:28.139653 [ 6500 ] {9ad8b468-ff05-4200-a9f4-528fa854a149} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43604) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:28.143550 [ 6500 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:29.630612 [ 6489 ] {1f5bd0e0-4c81-455b-ab14-cbf61a7c87e3} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43732) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:29.634519 [ 6489 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:29.690701 [ 3161 ] {8a78cedd-1a74-4b7f-9867-94fc787b0bd3} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43776) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:29.695499 [ 3161 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:29.873667 [ 6488 ] {6e159476-67fc-4c66-9ce6-c292b869e74c} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43862) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:29.877793 [ 6488 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:29.928890 [ 7799 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762b58 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:440: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000039414e06 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:223: DB::InterpreterKillQueryQuery::execute() @ 0x00000000393feea2 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:48:30.161481 [ 3093 ] {eac100f0-3b20-48ce-92ad-d995aebd2e3e} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43846) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:30.165339 [ 3093 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:30.292154 [ 3560 ] {15396d7f-11e7-4738-aacb-2b00d03d34bb} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50352) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:30.296192 [ 3560 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:30.540176 [ 6493 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:175: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d96f 9. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762e32 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:443: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000039414ecb 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:223: DB::InterpreterKillQueryQuery::execute() @ 0x00000000393feea2 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:48:31.142369 [ 6488 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762b58 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:440: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000039414e06 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:223: DB::InterpreterKillQueryQuery::execute() @ 0x00000000393feea2 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:48:31.557518 [ 3076 ] {411aa6da-26e7-4e1c-986c-d61eabf4e48b} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50554) (comment: 02461_cancel_finish_race.sh) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:31.568995 [ 3076 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:550: DB::QueryStatus::checkTimeLimit() @ 0x000000003897da63 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:200: DB::PipelineExecutor::finalizeExecution() @ 0x000000003f71cb87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:147: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c3f7 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:31.849988 [ 1429 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Interpreters/ProcessList.cpp:560: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000003897c899 5. ./build_docker/./src/Interpreters/ProcessList.cpp:513: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000003897c5b8 6. ./build_docker/./src/Interpreters/ProcessList.cpp:524: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x000000003897cc3c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:72: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003f71b431 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, void>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x0000000034afbce6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762b58 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:440: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000039414e06 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:223: DB::InterpreterKillQueryQuery::execute() @ 0x00000000393feea2 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:48:32.212120 [ 6498 ] {26fa4526-760a-426b-a0a1-4aa3f5a8decf} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:50568). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50568) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000020b76be5 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000020b7aee3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003f05f2aa 5. DB::WriteBuffer::next() @ 0x00000000088f6ec1 6. ./build_docker/./src/Server/TCPHandler.cpp:2544: DB::TCPHandler::runImpl() @ 0x000000003f42c5dc 7. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 13. ? @ 0x00007f583d9b1ac3 14. ? @ 0x00007f583da43850 2025.04.02 01:48:32.222742 [ 6498 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:50568). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000020b76be5 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000020b7aee3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003f05f2aa 5. DB::WriteBuffer::next() @ 0x00000000088f6ec1 6. ./build_docker/./src/Server/TCPHandler.cpp:2544: DB::TCPHandler::runImpl() @ 0x000000003f42c5dc 7. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 13. ? @ 0x00007f583d9b1ac3 14. ? @ 0x00007f583da43850 2025.04.02 01:48:32.224388 [ 6485 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:50524, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000020b76be5 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000020b7490f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000020b758a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003f05641a 6. DB::ReadBuffer::next() @ 0x0000000008c442cf 7. ./src/IO/ReadBuffer.h:103: DB::TCPHandler::runImpl() @ 0x000000003f42a233 8. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 14. ? @ 0x00007f583d9b1ac3 15. ? @ 0x00007f583da43850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:48:32.224388 [ 3300 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:50504, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000020b76be5 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000020b7490f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000020b758a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003f05641a 6. DB::ReadBuffer::next() @ 0x0000000008c442cf 7. ./src/IO/ReadBuffer.h:103: DB::TCPHandler::runImpl() @ 0x000000003f42a233 8. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 14. ? @ 0x00007f583d9b1ac3 15. ? @ 0x00007f583da43850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:48:32.224391 [ 3817 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:50584, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000020b76be5 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000020b7490f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000020b758a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003f05641a 6. DB::ReadBuffer::next() @ 0x0000000008c442cf 7. ./src/IO/ReadBuffer.h:103: DB::TCPHandler::runImpl() @ 0x000000003f42a233 8. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 14. ? @ 0x00007f583d9b1ac3 15. ? @ 0x00007f583da43850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:48:32.233134 [ 6485 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:50524, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000020b76be5 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000020b7490f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000020b758a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003f05641a 6. DB::ReadBuffer::next() @ 0x0000000008c442cf 7. ./src/IO/ReadBuffer.h:103: DB::TCPHandler::runImpl() @ 0x000000003f42a233 8. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 14. ? @ 0x00007f583d9b1ac3 15. ? @ 0x00007f583da43850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:48:32.235154 [ 3300 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:50504, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000020b76be5 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000020b7490f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000020b758a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003f05641a 6. DB::ReadBuffer::next() @ 0x0000000008c442cf 7. ./src/IO/ReadBuffer.h:103: DB::TCPHandler::runImpl() @ 0x000000003f42a233 8. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 14. ? @ 0x00007f583d9b1ac3 15. ? @ 0x00007f583da43850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:48:32.235430 [ 3817 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:50584, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000020b76be5 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000020b7490f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000020b758a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003f05641a 6. DB::ReadBuffer::next() @ 0x0000000008c442cf 7. ./src/IO/ReadBuffer.h:103: DB::TCPHandler::runImpl() @ 0x000000003f42a233 8. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 14. ? @ 0x00007f583d9b1ac3 15. ? @ 0x00007f583da43850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:48:32.509919 [ 3554 ] {0bc614ca-17e4-4467-9a09-f2c813a8be91} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50620) (comment: 02461_cancel_finish_race.sh) (in query: KILL QUERY WHERE current_database = 'test_e305txao' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. ./src/Common/Exception.h:105: _ZN2DB12NetExceptionC2IRA53_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEiOS5_ @ 0x000000003f487576 3. ./build_docker/./src/Server/TCPHandler.cpp:2400: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003f475217 4. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003f45127f 5. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000003f42c464 6. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:32.881722 [ 3554 ] {0bc614ca-17e4-4467-9a09-f2c813a8be91} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:50620). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000020b76be5 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000020b7b476 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003f05f2aa 5. DB::WriteBuffer::next() @ 0x00000000088f6ec1 6. ./build_docker/./src/Server/TCPHandler.cpp:2506: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003f47f6e1 7. ./build_docker/./src/Server/TCPHandler.cpp:2594: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003f45309f 8. ./build_docker/./src/Server/TCPHandler.cpp:816: DB::TCPHandler::runImpl() @ 0x000000003f42cf23 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:48:32.888474 [ 3554 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. ./src/Common/Exception.h:105: _ZN2DB12NetExceptionC2IRA53_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEiOS5_ @ 0x000000003f487576 3. ./build_docker/./src/Server/TCPHandler.cpp:2400: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003f475217 4. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003f45127f 5. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000003f42c464 6. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 2025.04.02 01:48:33.276469 [ 2377 ] {a2c7759d-acf9-4686-97e4-e4bde1c3aefa} executeQuery: Code: 386. DB::Exception: Cannot compare intervals IntervalNanosecond and IntervalMonth because the number of days in a month is not fixed: In scope SELECT toIntervalNanosecond(1) < toIntervalMonth(2). (NO_COMMON_TYPE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50416) (comment: 03223_interval_data_type_comparison.sql) (in query: SELECT INTERVAL 1 NANOSECOND < INTERVAL 2 MONTH;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000034de7814 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000034df2a85 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x0000000013d9a56b 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013d48484 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:48:33.281493 [ 2377 ] {} TCPHandler: Code: 386. DB::Exception: Cannot compare intervals IntervalNanosecond and IntervalMonth because the number of days in a month is not fixed: In scope SELECT toIntervalNanosecond(1) < toIntervalMonth(2). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000034de7814 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000034df2a85 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x0000000013d9a56b 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013d48484 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:48:33.920507 [ 2377 ] {5953d93b-dfdf-4e68-bfd9-41c2b328468f} executeQuery: Code: 386. DB::Exception: Cannot compare intervals IntervalMicrosecond and IntervalQuarter because the number of days in a month is not fixed: In scope SELECT toIntervalMicrosecond(36000000000000) < toIntervalQuarter(1). (NO_COMMON_TYPE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50416) (comment: 03223_interval_data_type_comparison.sql) (in query: SELECT INTERVAL 36000000000000 MICROSECOND < INTERVAL 1 QUARTER;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000034de7814 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000034df2a85 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x0000000013d9a56b 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013d48484 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:48:33.923760 [ 2377 ] {} TCPHandler: Code: 386. DB::Exception: Cannot compare intervals IntervalMicrosecond and IntervalQuarter because the number of days in a month is not fixed: In scope SELECT toIntervalMicrosecond(36000000000000) < toIntervalQuarter(1). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000034de7814 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000034df2a85 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x0000000013d9a56b 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013d48484 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:48:34.482797 [ 2377 ] {8cb64295-cb03-4940-8e4d-e06b97147265} executeQuery: Code: 386. DB::Exception: Cannot compare intervals IntervalMillisecond and IntervalYear because the number of days in a month is not fixed: In scope SELECT toIntervalMillisecond(36000000000000) < toIntervalYear(1). (NO_COMMON_TYPE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50416) (comment: 03223_interval_data_type_comparison.sql) (in query: SELECT INTERVAL 36000000000000 MILLISECOND < INTERVAL 1 YEAR;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000034de7814 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000034df2a85 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x0000000013d9a56b 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013d48484 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:48:34.486200 [ 2377 ] {} TCPHandler: Code: 386. DB::Exception: Cannot compare intervals IntervalMillisecond and IntervalYear because the number of days in a month is not fixed: In scope SELECT toIntervalMillisecond(36000000000000) < toIntervalYear(1). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000034de7814 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000034df2a85 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x0000000013d9a56b 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013d48484 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:48:34.963529 [ 2377 ] {91d15224-d7e7-4d3d-a0c3-08b3fefed8a4} executeQuery: Code: 386. DB::Exception: Cannot compare intervals IntervalSecond and IntervalMonth because the number of days in a month is not fixed: In scope SELECT toIntervalSecond(36000000000000) < toIntervalMonth(1). (NO_COMMON_TYPE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50416) (comment: 03223_interval_data_type_comparison.sql) (in query: SELECT INTERVAL 36000000000000 SECOND < INTERVAL 1 MONTH;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000034de7814 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000034df2a85 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x0000000013d9a56b 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013d48484 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:48:34.966893 [ 2377 ] {} TCPHandler: Code: 386. DB::Exception: Cannot compare intervals IntervalSecond and IntervalMonth because the number of days in a month is not fixed: In scope SELECT toIntervalSecond(36000000000000) < toIntervalMonth(1). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000034de7814 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000034df2a85 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x0000000013d9a56b 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013d48484 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:48:36.317523 [ 2377 ] {e2924d7d-2fa2-4419-89e5-e390cfc3eb8e} executeQuery: Code: 386. DB::Exception: Cannot compare intervals IntervalMinute and IntervalQuarter because the number of days in a month is not fixed: In scope SELECT toIntervalMinute(2) = toIntervalQuarter(120). (NO_COMMON_TYPE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50416) (comment: 03223_interval_data_type_comparison.sql) (in query: SELECT INTERVAL 2 MINUTE = INTERVAL 120 QUARTER;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000034de7814 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000034df2a85 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000e4e2b6b 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e490364 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:48:36.321418 [ 2377 ] {} TCPHandler: Code: 386. DB::Exception: Cannot compare intervals IntervalMinute and IntervalQuarter because the number of days in a month is not fixed: In scope SELECT toIntervalMinute(2) = toIntervalQuarter(120). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000034de7814 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000034df2a85 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000e4e2b6b 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e490364 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:48:36.593446 [ 2377 ] {633efbbc-5af1-400d-96df-83e019dc10c9} executeQuery: Code: 386. DB::Exception: Cannot compare intervals IntervalHour and IntervalYear because the number of days in a month is not fixed: In scope SELECT toIntervalHour(2) < toIntervalYear(1). (NO_COMMON_TYPE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50416) (comment: 03223_interval_data_type_comparison.sql) (in query: SELECT INTERVAL 2 HOUR < INTERVAL 1 YEAR;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000034de7814 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000034df2a85 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x0000000013d9a56b 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013d48484 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:48:36.596127 [ 2377 ] {} TCPHandler: Code: 386. DB::Exception: Cannot compare intervals IntervalHour and IntervalYear because the number of days in a month is not fixed: In scope SELECT toIntervalHour(2) < toIntervalYear(1). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000034de7814 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000034df2a85 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x0000000013d9a56b 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013d48484 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:48:36.791558 [ 2377 ] {e0e61369-b4f5-4332-bca0-f473a87f04c6} executeQuery: Code: 386. DB::Exception: Cannot compare intervals IntervalDay and IntervalMonth because the number of days in a month is not fixed: In scope SELECT toIntervalDay(2) = toIntervalMonth(48). (NO_COMMON_TYPE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50416) (comment: 03223_interval_data_type_comparison.sql) (in query: SELECT INTERVAL 2 DAY = INTERVAL 48 MONTH;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000034de7814 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000034df2a85 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000e4e2b6b 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e490364 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:48:36.794728 [ 2377 ] {} TCPHandler: Code: 386. DB::Exception: Cannot compare intervals IntervalDay and IntervalMonth because the number of days in a month is not fixed: In scope SELECT toIntervalDay(2) = toIntervalMonth(48). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000034de7814 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000034df2a85 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000e4e2b6b 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e490364 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:48:37.677358 [ 2377 ] {2fd9e1eb-318e-4fc1-a241-761ebba588da} executeQuery: Code: 386. DB::Exception: Cannot compare intervals IntervalWeek and IntervalQuarter because the number of days in a month is not fixed: In scope SELECT toIntervalWeek(124) > toIntervalQuarter(8). (NO_COMMON_TYPE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50416) (comment: 03223_interval_data_type_comparison.sql) (in query: SELECT INTERVAL 124 WEEK > INTERVAL 8 QUARTER;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000034de7814 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000034df2a85 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000f826a0b 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f7d4a84 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:48:37.680366 [ 2377 ] {} TCPHandler: Code: 386. DB::Exception: Cannot compare intervals IntervalWeek and IntervalQuarter because the number of days in a month is not fixed: In scope SELECT toIntervalWeek(124) > toIntervalQuarter(8). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000034de7814 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000034df2a85 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000f826a0b 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f7d4a84 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:48:37.930121 [ 2377 ] {292e48a7-1011-42d4-ba67-f90fafa8679d} executeQuery: Code: 386. DB::Exception: Cannot compare intervals IntervalMonth and IntervalMicrosecond because the number of days in a month is not fixed: In scope SELECT toIntervalMonth(6) = toIntervalMicrosecond(26). (NO_COMMON_TYPE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50416) (comment: 03223_interval_data_type_comparison.sql) (in query: SELECT INTERVAL 6 MONTH = INTERVAL 26 MICROSECOND;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000034de7814 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000034df2a85 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000e4e2b6b 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e490364 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:48:37.933151 [ 2377 ] {} TCPHandler: Code: 386. DB::Exception: Cannot compare intervals IntervalMonth and IntervalMicrosecond because the number of days in a month is not fixed: In scope SELECT toIntervalMonth(6) = toIntervalMicrosecond(26). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000034de7814 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000034df2a85 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000e4e2b6b 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e490364 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:48:38.144985 [ 2377 ] {d39fd07d-5642-4a72-847f-e0cf5c50d8fe} executeQuery: Code: 386. DB::Exception: Cannot compare intervals IntervalQuarter and IntervalNanosecond because the number of days in a month is not fixed: In scope SELECT toIntervalQuarter(2) = toIntervalNanosecond(6). (NO_COMMON_TYPE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50416) (comment: 03223_interval_data_type_comparison.sql) (in query: SELECT INTERVAL 2 QUARTER = INTERVAL 6 NANOSECOND;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000034de7814 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000034df2a85 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000e4e2b6b 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e490364 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:48:38.149879 [ 2377 ] {} TCPHandler: Code: 386. DB::Exception: Cannot compare intervals IntervalQuarter and IntervalNanosecond because the number of days in a month is not fixed: In scope SELECT toIntervalQuarter(2) = toIntervalNanosecond(6). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000034de7814 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000034df2a85 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000e4e2b6b 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e490364 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:48:38.284111 [ 2377 ] {2106919f-2cfc-418b-a0a6-75790dceee8c} executeQuery: Code: 386. DB::Exception: Cannot compare intervals IntervalYear and IntervalSecond because the number of days in a month is not fixed: In scope SELECT toIntervalYear(2) = toIntervalSecond(8). (NO_COMMON_TYPE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50416) (comment: 03223_interval_data_type_comparison.sql) (in query: SELECT INTERVAL 2 YEAR = INTERVAL 8 SECOND;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000034de7814 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000034df2a85 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000e4e2b6b 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e490364 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:48:38.287542 [ 2377 ] {} TCPHandler: Code: 386. DB::Exception: Cannot compare intervals IntervalYear and IntervalSecond because the number of days in a month is not fixed: In scope SELECT toIntervalYear(2) = toIntervalSecond(8). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000034de7814 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000034df2a85 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000e4e2b6b 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e490364 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:48:41.396871 [ 6485 ] {0554f31c-d5a3-40ab-bf60-b19addd92895} executeQuery: Code: 59. DB::Exception: Invalid type for filter in HAVING: Nothing. In query SELECT (NULL, NULL, NULL, NULL, NULL, NULL, NULL) FROM numbers(0) GROUP BY number WITH TOTALS HAVING sum(number) <= arrayJoin([]). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:35308) (comment: 02233_with_total_empty_chunk.sql) (in query: SELECT (NULL, NULL, NULL, NULL, NULL, NULL, NULL) FROM numbers(0) GROUP BY number WITH TOTALS HAVING sum(number) <= arrayJoin([]) -- { serverError ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER }; ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x0000000034387ff7 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x0000000035e87016 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:77: DB::validateFilters(std::shared_ptr const&) @ 0x0000000035e8639f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5734: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d2906b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 17. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 18. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 24. ? @ 0x00007f583d9b1ac3 25. ? @ 0x00007f583da43850 2025.04.02 01:48:41.400995 [ 6485 ] {} TCPHandler: Code: 59. DB::Exception: Invalid type for filter in HAVING: Nothing. In query SELECT (NULL, NULL, NULL, NULL, NULL, NULL, NULL) FROM numbers(0) GROUP BY number WITH TOTALS HAVING sum(number) <= arrayJoin([]). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x0000000034387ff7 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x0000000035e87016 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:77: DB::validateFilters(std::shared_ptr const&) @ 0x0000000035e8639f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5734: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d2906b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 17. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 18. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 24. ? @ 0x00007f583d9b1ac3 25. ? @ 0x00007f583da43850 2025.04.02 01:48:44.367160 [ 3093 ] {32607def-aca0-4eb7-a081-1512f9cb0f9b} executeQuery: Code: 15. DB::Exception: Column 'tupleElement(CAST(tuple(1), 'Tuple(a Int)'), 1)' already exists: While processing CAST(tuple(1), 'Tuple(a Int)').1, untuple(CAST(tuple(1), 'Tuple(a Int)')). (DUPLICATE_COLUMN) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:35420) (comment: 02890_untuple_column_names.sql) (in query: SELECT untuple(tuple(1)::Tuple(a Int)), untuple(tuple(1)::Tuple(a Int)) FORMAT Vertical SETTINGS enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ac716ea 4. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:483: DB::ScopeStack::Index::addNode(DB::ActionsDAG::Node const*) @ 0x0000000036a444f4 5. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:674: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000036a1b7e8 6. ./src/Interpreters/ActionsVisitor.h:178: DB::ActionsMatcher::doUntuple(DB::ASTFunction const*, DB::ActionsMatcher::Data&) @ 0x0000000036a3767c 7. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:833: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a3404b 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:736: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a1d3f5 9. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000369f7f95 10. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000036972ab7 11. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1588: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x000000003699f7a1 12. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2173: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x00000000369b1b6f 13. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1172: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000038577594 14. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:911: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000038555b7d 15. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:921: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000038540a77 16. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:302: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000385322f1 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000387b4479 18. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:165: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000387aedda 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000387c2eee 20. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000387bcff3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:48:44.370389 [ 3093 ] {} TCPHandler: Code: 15. DB::Exception: Column 'tupleElement(CAST(tuple(1), 'Tuple(a Int)'), 1)' already exists: While processing CAST(tuple(1), 'Tuple(a Int)').1, untuple(CAST(tuple(1), 'Tuple(a Int)')). (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ac716ea 4. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:483: DB::ScopeStack::Index::addNode(DB::ActionsDAG::Node const*) @ 0x0000000036a444f4 5. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:674: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000036a1b7e8 6. ./src/Interpreters/ActionsVisitor.h:178: DB::ActionsMatcher::doUntuple(DB::ASTFunction const*, DB::ActionsMatcher::Data&) @ 0x0000000036a3767c 7. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:833: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a3404b 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:736: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a1d3f5 9. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000369f7f95 10. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000036972ab7 11. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1588: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x000000003699f7a1 12. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2173: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x00000000369b1b6f 13. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1172: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000038577594 14. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:911: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000038555b7d 15. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:921: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000038540a77 16. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:302: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000385322f1 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000387b4479 18. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:165: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000387aedda 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000387c2eee 20. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000387bcff3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:48:44.531255 [ 3093 ] {255b4cab-3790-4807-bcc7-1e99e9751f5e} executeQuery: Code: 15. DB::Exception: Column 'tupleElement(CAST(tuple(1), 'Tuple(a Int)'), 1)' already exists: While processing CAST(tuple(1), 'Tuple(a Int)').1 AS `x.a`, untuple(CAST(tuple(1), 'Tuple(a Int)')) AS x. (DUPLICATE_COLUMN) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:35420) (comment: 02890_untuple_column_names.sql) (in query: SELECT untuple(tuple(1)::Tuple(a Int)) x, untuple(tuple(1)::Tuple(a Int)) x FORMAT Vertical SETTINGS enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ac716ea 4. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:483: DB::ScopeStack::Index::addNode(DB::ActionsDAG::Node const*) @ 0x0000000036a444f4 5. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:674: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000036a1b7e8 6. ./src/Interpreters/ActionsVisitor.h:178: DB::ActionsMatcher::doUntuple(DB::ASTFunction const*, DB::ActionsMatcher::Data&) @ 0x0000000036a3767c 7. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:833: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a3404b 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:736: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a1d3f5 9. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000369f7f95 10. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000036972ab7 11. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1588: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x000000003699f7a1 12. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2173: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x00000000369b1b6f 13. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1172: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000038577594 14. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:911: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000038555b7d 15. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:921: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000038540a77 16. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:302: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000385322f1 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000387b4479 18. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:165: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000387aedda 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000387c2eee 20. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000387bcff3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:48:44.534079 [ 3093 ] {} TCPHandler: Code: 15. DB::Exception: Column 'tupleElement(CAST(tuple(1), 'Tuple(a Int)'), 1)' already exists: While processing CAST(tuple(1), 'Tuple(a Int)').1 AS `x.a`, untuple(CAST(tuple(1), 'Tuple(a Int)')) AS x. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ac716ea 4. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:483: DB::ScopeStack::Index::addNode(DB::ActionsDAG::Node const*) @ 0x0000000036a444f4 5. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:674: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000036a1b7e8 6. ./src/Interpreters/ActionsVisitor.h:178: DB::ActionsMatcher::doUntuple(DB::ASTFunction const*, DB::ActionsMatcher::Data&) @ 0x0000000036a3767c 7. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:833: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a3404b 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:736: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a1d3f5 9. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000369f7f95 10. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000036972ab7 11. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1588: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x000000003699f7a1 12. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2173: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x00000000369b1b6f 13. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1172: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000038577594 14. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:911: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000038555b7d 15. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:921: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000038540a77 16. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:302: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000385322f1 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000387b4479 18. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:165: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000387aedda 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000387c2eee 20. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000387bcff3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:48:44.701084 [ 3093 ] {7f1874af-3bb8-4bcc-9908-6a372fa9dddd} executeQuery: Code: 15. DB::Exception: Column 'tupleElement(CAST(tuple(1), 'Tuple(Int)'), 1)' already exists: While processing CAST(tuple(1), 'Tuple(Int)').1 AS `x.1`, untuple(CAST(tuple(1), 'Tuple(Int)')) AS x. (DUPLICATE_COLUMN) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:35420) (comment: 02890_untuple_column_names.sql) (in query: SELECT untuple(tuple(1)::Tuple(Int)) x, untuple(tuple(1)::Tuple(Int)) x FORMAT Vertical SETTINGS enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ac716ea 4. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:483: DB::ScopeStack::Index::addNode(DB::ActionsDAG::Node const*) @ 0x0000000036a444f4 5. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:674: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000036a1b7e8 6. ./src/Interpreters/ActionsVisitor.h:178: DB::ActionsMatcher::doUntuple(DB::ASTFunction const*, DB::ActionsMatcher::Data&) @ 0x0000000036a3767c 7. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:833: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a3404b 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:736: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a1d3f5 9. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000369f7f95 10. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000036972ab7 11. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1588: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x000000003699f7a1 12. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2173: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x00000000369b1b6f 13. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1172: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000038577594 14. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:911: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000038555b7d 15. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:921: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000038540a77 16. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:302: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000385322f1 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000387b4479 18. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:165: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000387aedda 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000387c2eee 20. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000387bcff3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:48:44.703964 [ 3093 ] {} TCPHandler: Code: 15. DB::Exception: Column 'tupleElement(CAST(tuple(1), 'Tuple(Int)'), 1)' already exists: While processing CAST(tuple(1), 'Tuple(Int)').1 AS `x.1`, untuple(CAST(tuple(1), 'Tuple(Int)')) AS x. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ac716ea 4. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:483: DB::ScopeStack::Index::addNode(DB::ActionsDAG::Node const*) @ 0x0000000036a444f4 5. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:674: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000036a1b7e8 6. ./src/Interpreters/ActionsVisitor.h:178: DB::ActionsMatcher::doUntuple(DB::ASTFunction const*, DB::ActionsMatcher::Data&) @ 0x0000000036a3767c 7. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:833: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a3404b 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:736: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a1d3f5 9. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000369f7f95 10. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000036972ab7 11. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1588: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x000000003699f7a1 12. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2173: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x00000000369b1b6f 13. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1172: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000038577594 14. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:911: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000038555b7d 15. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:921: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000038540a77 16. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:302: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000385322f1 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000387b4479 18. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:165: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000387aedda 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000387c2eee 20. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000387bcff3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:48:44.868718 [ 3093 ] {dc4b4b1f-72ec-4b2d-9c35-6968c4949974} executeQuery: Code: 15. DB::Exception: Column 'tupleElement(CAST(tuple(1), 'Tuple(Int)'), 1)' already exists: While processing CAST(tuple(1), 'Tuple(Int)').1, untuple(CAST(tuple(1), 'Tuple(Int)')). (DUPLICATE_COLUMN) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:35420) (comment: 02890_untuple_column_names.sql) (in query: SELECT untuple(tuple(1)::Tuple(Int)), untuple(tuple(1)::Tuple(Int)) FORMAT Vertical SETTINGS enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ac716ea 4. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:483: DB::ScopeStack::Index::addNode(DB::ActionsDAG::Node const*) @ 0x0000000036a444f4 5. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:674: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000036a1b7e8 6. ./src/Interpreters/ActionsVisitor.h:178: DB::ActionsMatcher::doUntuple(DB::ASTFunction const*, DB::ActionsMatcher::Data&) @ 0x0000000036a3767c 7. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:833: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a3404b 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:736: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a1d3f5 9. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000369f7f95 10. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000036972ab7 11. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1588: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x000000003699f7a1 12. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2173: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x00000000369b1b6f 13. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1172: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000038577594 14. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:911: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000038555b7d 15. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:921: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000038540a77 16. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:302: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000385322f1 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000387b4479 18. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:165: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000387aedda 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000387c2eee 20. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000387bcff3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:48:44.871907 [ 3093 ] {} TCPHandler: Code: 15. DB::Exception: Column 'tupleElement(CAST(tuple(1), 'Tuple(Int)'), 1)' already exists: While processing CAST(tuple(1), 'Tuple(Int)').1, untuple(CAST(tuple(1), 'Tuple(Int)')). (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ac716ea 4. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:483: DB::ScopeStack::Index::addNode(DB::ActionsDAG::Node const*) @ 0x0000000036a444f4 5. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:674: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000036a1b7e8 6. ./src/Interpreters/ActionsVisitor.h:178: DB::ActionsMatcher::doUntuple(DB::ASTFunction const*, DB::ActionsMatcher::Data&) @ 0x0000000036a3767c 7. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:833: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a3404b 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:736: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000036a1d3f5 9. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000369f7f95 10. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000036972ab7 11. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1588: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x000000003699f7a1 12. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2173: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x00000000369b1b6f 13. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1172: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000038577594 14. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:911: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000038555b7d 15. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:921: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000038540a77 16. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:302: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000385322f1 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000387b4479 18. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:165: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000387aedda 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000387c2eee 20. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000387bcff3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:48:45.693000 [ 3161 ] {316b3b04-c067-4701-9616-da92daddf7d1} executeQuery: Code: 524. DB::Exception: Cannot alter version column version to type String because version column must be of an integer type or of type Date or DateTime. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:35472) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (in query: ALTER TABLE table_with_version MODIFY COLUMN version String;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3404: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003deb4e96 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:218: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775be7b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:48:45.695988 [ 3161 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter version column version to type String because version column must be of an integer type or of type Date or DateTime. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3404: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003deb4e96 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:218: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775be7b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:48:46.142299 [ 3161 ] {04cec8c4-5160-4548-bcaf-fcc7c01a0183} executeQuery: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Int64 because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:35472) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (in query: ALTER TABLE table_with_version MODIFY COLUMN version Int64;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008b276d7 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3420: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003deb6137 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:218: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775be7b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:48:46.145299 [ 3161 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Int64 because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008b276d7 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3420: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003deb6137 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:218: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775be7b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:48:46.584908 [ 3161 ] {f3cd8cd4-3f74-4c56-a555-4a4596f70e95} executeQuery: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type UInt16 because new type is smaller than current in the number of bytes. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:35472) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (in query: ALTER TABLE table_with_version MODIFY COLUMN version UInt16;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008b276d7 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3429: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003deb6010 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:218: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775be7b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:48:46.587682 [ 3161 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type UInt16 because new type is smaller than current in the number of bytes. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008b276d7 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3429: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003deb6010 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:218: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775be7b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:48:46.610069 [ 3161 ] {ab3d3d36-6cba-4d2a-8f92-2478e937930e} executeQuery: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Float64 because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:35472) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (in query: ALTER TABLE table_with_version MODIFY COLUMN version Float64;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008b276d7 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3420: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003deb6137 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:218: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775be7b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:48:46.612698 [ 3161 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Float64 because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008b276d7 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3420: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003deb6137 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:218: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775be7b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:48:46.634249 [ 3161 ] {f0f7ea6b-ee2f-4181-a823-10477f192d2a} executeQuery: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Date because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:35472) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (in query: ALTER TABLE table_with_version MODIFY COLUMN version Date;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008b276d7 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3420: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003deb6137 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:218: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775be7b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:48:46.637105 [ 3161 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Date because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008b276d7 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3420: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003deb6137 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:218: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775be7b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:48:46.659110 [ 3161 ] {a450a8a3-4177-44c9-b53d-5677ac684945} executeQuery: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type DateTime because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:35472) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (in query: ALTER TABLE table_with_version MODIFY COLUMN version DateTime;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008b276d7 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3420: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003deb6137 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:218: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775be7b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:48:46.661917 [ 3161 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type DateTime because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008b276d7 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3420: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003deb6137 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:218: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775be7b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:48:49.545014 [ 6488 ] {8004fac4-7f8c-4c64-831f-cb3e1332a59d} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function toUInt64: In scope SELECT dictGet('02176_test_simple_key_dictionary', 'value', [0]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:35586) (comment: 02176_dict_get_has_implicit_key_cast.sql) (in query: SELECT dictGet('02176_test_simple_key_dictionary', 'value', [0]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003252d17b 5. ./src/Functions/FunctionsConversion.h:2292: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003252b702 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000031eab4c9 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 16. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 17. ./build_docker/./src/Interpreters/castColumn.cpp:38: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000391a69fe 18. ./build_docker/./src/Interpreters/castColumn.cpp:48: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000391a7a3c 19. ./src/Dictionaries/IDictionary.h:166: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x0000000027f490ca 20. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008e56d42 21. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 22. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 24. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 2025.04.02 01:48:49.548408 [ 6488 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function toUInt64: In scope SELECT dictGet('02176_test_simple_key_dictionary', 'value', [0]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003252d17b 5. ./src/Functions/FunctionsConversion.h:2292: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003252b702 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000031eab4c9 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 16. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 17. ./build_docker/./src/Interpreters/castColumn.cpp:38: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000391a69fe 18. ./build_docker/./src/Interpreters/castColumn.cpp:48: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000391a7a3c 19. ./src/Dictionaries/IDictionary.h:166: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x0000000027f490ca 20. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008e56d42 21. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 22. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 24. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 2025.04.02 01:48:50.782267 [ 6488 ] {59c0ce40-1080-46aa-bfb1-a77ad611f162} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function toUInt64: In scope SELECT dictHas('02176_test_simple_key_dictionary', [0]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:35586) (comment: 02176_dict_get_has_implicit_key_cast.sql) (in query: SELECT dictHas('02176_test_simple_key_dictionary', [0]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003252d17b 5. ./src/Functions/FunctionsConversion.h:2292: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003252b702 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000031eab4c9 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 16. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 17. ./build_docker/./src/Interpreters/castColumn.cpp:38: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000391a69fe 18. ./build_docker/./src/Interpreters/castColumn.cpp:48: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000391a7a3c 19. ./src/Dictionaries/IDictionary.h:166: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x0000000027f490ca 20. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008e8e148 21. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 22. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 24. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 2025.04.02 01:48:50.785974 [ 6488 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function toUInt64: In scope SELECT dictHas('02176_test_simple_key_dictionary', [0]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003252d17b 5. ./src/Functions/FunctionsConversion.h:2292: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003252b702 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000031eab4c9 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 16. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 17. ./build_docker/./src/Interpreters/castColumn.cpp:38: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000391a69fe 18. ./build_docker/./src/Interpreters/castColumn.cpp:48: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000391a7a3c 19. ./src/Dictionaries/IDictionary.h:166: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x0000000027f490ca 20. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008e8e148 21. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 22. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 24. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 2025.04.02 01:48:51.289073 [ 6488 ] {3ea63b82-ad61-4518-a17c-532ddf32dc85} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function toUInt64: In scope SELECT dictGet('02176_test_complex_key_dictionary', 'value', ([0], '0')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:35586) (comment: 02176_dict_get_has_implicit_key_cast.sql) (in query: SELECT dictGet('02176_test_complex_key_dictionary', 'value', tuple([0], '0'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003252d17b 5. ./src/Functions/FunctionsConversion.h:2292: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003252b702 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000031eab4c9 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 16. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 17. ./build_docker/./src/Interpreters/castColumn.cpp:38: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000391a69fe 18. ./build_docker/./src/Interpreters/castColumn.cpp:48: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000391a7a3c 19. ./src/Dictionaries/IDictionary.h:166: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x0000000027f490ca 20. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008e56d42 21. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 22. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 24. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 2025.04.02 01:48:51.292425 [ 6488 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function toUInt64: In scope SELECT dictGet('02176_test_complex_key_dictionary', 'value', ([0], '0')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003252d17b 5. ./src/Functions/FunctionsConversion.h:2292: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003252b702 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000031eab4c9 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 16. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 17. ./build_docker/./src/Interpreters/castColumn.cpp:38: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000391a69fe 18. ./build_docker/./src/Interpreters/castColumn.cpp:48: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000391a7a3c 19. ./src/Dictionaries/IDictionary.h:166: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x0000000027f490ca 20. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008e56d42 21. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 22. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 24. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 2025.04.02 01:48:51.674367 [ 6488 ] {0c9aead8-e2f9-4f52-8ff0-cd13caaa4c77} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function toUInt64: In scope SELECT dictHas('02176_test_complex_key_dictionary', ([0], '0')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:35586) (comment: 02176_dict_get_has_implicit_key_cast.sql) (in query: SELECT dictHas('02176_test_complex_key_dictionary', tuple([0], '0'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003252d17b 5. ./src/Functions/FunctionsConversion.h:2292: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003252b702 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000031eab4c9 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 16. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 17. ./build_docker/./src/Interpreters/castColumn.cpp:38: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000391a69fe 18. ./build_docker/./src/Interpreters/castColumn.cpp:48: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000391a7a3c 19. ./src/Dictionaries/IDictionary.h:166: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x0000000027f490ca 20. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008e8e148 21. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 22. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 24. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 2025.04.02 01:48:51.677539 [ 6488 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function toUInt64: In scope SELECT dictHas('02176_test_complex_key_dictionary', ([0], '0')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003252d17b 5. ./src/Functions/FunctionsConversion.h:2292: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003252b702 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000031eab4c9 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031e114f6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf757f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 16. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 17. ./build_docker/./src/Interpreters/castColumn.cpp:38: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000391a69fe 18. ./build_docker/./src/Interpreters/castColumn.cpp:48: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000391a7a3c 19. ./src/Dictionaries/IDictionary.h:166: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x0000000027f490ca 20. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008e8e148 21. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 22. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 24. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 2025.04.02 01:48:52.280637 [ 6495 ] {c4687abe-969b-4386-adfd-e37f7e324060} executeQuery: Code: 36. DB::Exception: Argument 'ttl' must be a literal, get Identifier_k (value: k). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43162) (comment: 02811_invalid_embedded_rocksdb_create.sql) (in query: CREATE TABLE dict (`k` String, `v` String) ENGINE = EmbeddedRocksDB(k) PRIMARY KEY k;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x00000000273f45b7 4. ./build_docker/./src/Storages/checkAndGetLiteralArgument.cpp:25: unsigned long DB::checkAndGetLiteralArgument(std::shared_ptr const&, String const&) @ 0x000000003d3e4305 5. ./build_docker/./src/Storages/RocksDB/StorageEmbeddedRocksDB.cpp:697: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000334ffbf9 6. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000033526b3a 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003c9464fa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377e8869 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 20. ? @ 0x00007f583d9b1ac3 21. ? @ 0x00007f583da43850 2025.04.02 01:48:52.284097 [ 6495 ] {} TCPHandler: Code: 36. DB::Exception: Argument 'ttl' must be a literal, get Identifier_k (value: k). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x00000000273f45b7 4. ./build_docker/./src/Storages/checkAndGetLiteralArgument.cpp:25: unsigned long DB::checkAndGetLiteralArgument(std::shared_ptr const&, String const&) @ 0x000000003d3e4305 5. ./build_docker/./src/Storages/RocksDB/StorageEmbeddedRocksDB.cpp:697: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000334ffbf9 6. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000033526b3a 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003c9464fa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377e8869 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 20. ? @ 0x00007f583d9b1ac3 21. ? @ 0x00007f583da43850 2025.04.02 01:48:56.148673 [ 6500 ] {74bf4c17-bbdb-4cd5-8fc8-236eb6f288e7} executeQuery: Code: 167. DB::Exception: AST is too deep. Maximum: 1000. (TOO_DEEP_AST) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:46634) (comment: 01196_max_parser_depth.sh) (in query: select coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, 1))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000009f9b88a 4. ./build_docker/./src/Parsers/IAST.cpp:162: DB::IAST::checkDepthImpl(unsigned long) const @ 0x00000000425aa2f4 5. ./src/Parsers/IAST.h:98: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042709132 6. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 7. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 8. ./build_docker/./src/Interpreters/executeQuery.cpp:876: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003926dc04 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1667: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000039288b06 10. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003f279970 11. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003f285729 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003f4a8b63 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:48:56.152113 [ 6500 ] {74bf4c17-bbdb-4cd5-8fc8-236eb6f288e7} DynamicQueryHandler: Code: 167. DB::Exception: AST is too deep. Maximum: 1000. (TOO_DEEP_AST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000009f9b88a 4. ./build_docker/./src/Parsers/IAST.cpp:162: DB::IAST::checkDepthImpl(unsigned long) const @ 0x00000000425aa2f4 5. ./src/Parsers/IAST.h:98: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000042709132 6. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c650 7. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 8. ./build_docker/./src/Interpreters/executeQuery.cpp:876: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003926dc04 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1667: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000039288b06 10. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003f279970 11. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003f285729 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003f4a8b63 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:48:57.641192 [ 6493 ] {7d5e851c-5d99-47d8-ab50-cf896d5c8cab} executeQuery: Code: 43. DB::Exception: addMilliseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') + toIntervalMillisecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43270) (comment: 01099_operators_date_and_timestamp.sql) (in query: select (date '2001-09-29' + interval 12345 millisecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000ae28a65 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000adf0a07 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019b34b40 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001931d679 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009f867c6 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 30. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 31. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 2025.04.02 01:48:57.644358 [ 6493 ] {} TCPHandler: Code: 43. DB::Exception: addMilliseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') + toIntervalMillisecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000ae28a65 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000adf0a07 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019b34b40 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001931d679 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009f867c6 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 30. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 31. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 2025.04.02 01:48:57.739212 [ 6484 ] {65f3b731-7bcc-433a-8cd8-7ac53e4fd9ba} executeQuery: Code: 70. DB::Exception: Conversion from AggregateFunction(sum, UInt8) to AggregateFunction(sum, Int32) is not supported: while converting source column pv to destination column pv. (CANNOT_CONVERT_TYPE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43288) (comment: 01880_materialized_view_to_table_type_check.sql) (in query: CREATE MATERIALIZED VIEW test_mv to test(`id` Int32, `pv` AggregateFunction(sum, Int32)) as SELECT id, sumState(1) as pv from test_input group by id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. DB::detail::FunctionCast::createAggregateFunctionWrapper(std::shared_ptr const&, DB::DataTypeAggregateFunction const*) const @ 0x0000000031e64665 5. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000031e58018 6. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000031e147a1 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000031e0ff88 8. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000031e0ec85 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:335: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x0000000035aebfe7 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:294: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000035aef390 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1567: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000035b36098 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1174: DB::InterpreterCreateQuery::validateMaterializedViewColumnsAndEngine(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&, std::shared_ptr const&) @ 0x00000000377bc8e8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1678: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cafc6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 17. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 18. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 24. ? @ 0x00007f583d9b1ac3 25. ? @ 0x00007f583da43850 2025.04.02 01:48:57.744016 [ 6484 ] {} TCPHandler: Code: 70. DB::Exception: Conversion from AggregateFunction(sum, UInt8) to AggregateFunction(sum, Int32) is not supported: while converting source column pv to destination column pv. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. DB::detail::FunctionCast::createAggregateFunctionWrapper(std::shared_ptr const&, DB::DataTypeAggregateFunction const*) const @ 0x0000000031e64665 5. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000031e58018 6. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000031e147a1 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000031e0ff88 8. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000031e0ec85 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:335: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x0000000035aebfe7 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:294: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000035aef390 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1567: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000035b36098 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1174: DB::InterpreterCreateQuery::validateMaterializedViewColumnsAndEngine(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&, std::shared_ptr const&) @ 0x00000000377bc8e8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1678: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cafc6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 17. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 18. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 24. ? @ 0x00007f583d9b1ac3 25. ? @ 0x00007f583da43850 2025.04.02 01:48:58.509886 [ 6493 ] {ed0640c5-5922-42f4-a4a6-86cacfea5a5e} executeQuery: Code: 43. DB::Exception: addMicroseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') + toIntervalMicrosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43270) (comment: 01099_operators_date_and_timestamp.sql) (in query: select (date '2001-09-29' + interval 12345 microsecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000aded145 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000adb4ac7 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019b34b40 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001931d679 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009f867c6 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 30. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 31. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 2025.04.02 01:48:58.512933 [ 6493 ] {} TCPHandler: Code: 43. DB::Exception: addMicroseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') + toIntervalMicrosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000aded145 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000adb4ac7 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019b34b40 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001931d679 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009f867c6 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 30. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 31. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 2025.04.02 01:48:59.390380 [ 6493 ] {33acc0c5-4f03-4f91-87f2-3dfa360313bb} executeQuery: Code: 43. DB::Exception: addNanoseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') + toIntervalNanosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43270) (comment: 01099_operators_date_and_timestamp.sql) (in query: select (date '2001-09-29' + interval 12345 nanosecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000aee2985 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aea38e7 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019b34b40 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001931d679 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009f867c6 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 30. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 31. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 2025.04.02 01:48:59.393743 [ 6493 ] {} TCPHandler: Code: 43. DB::Exception: addNanoseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') + toIntervalNanosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000aee2985 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aea38e7 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019b34b40 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001931d679 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009f867c6 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 30. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 31. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 2025.04.02 01:48:59.943913 [ 6488 ] {67c9a22d-cc7a-4d10-9c55-73613de0e07c} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 241. DB::Exception: Query memory limit exceeded: would use 8.00 GiB (attempt to allocate chunk of 8589803912 bytes), current RSS 14.25 MiB, maximum: 953.67 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000207409d0 4. ./build_docker/./src/Common/MemoryTracker.cpp:322: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002073d3c1 5. ./build_docker/./src/Common/MemoryTracker.cpp:383: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002073c803 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:58: CurrentMemoryTracker::alloc(long) @ 0x000000002061ade9 7. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x0000000020616543 8. ./src/Common/PODArray.h:152: COW::immutable_ptr DB::ColumnArray::replicateNumber(DB::PODArray, 63ul, 64ul> const&) const @ 0x000000003b57a188 9. ./build_docker/./src/Columns/ColumnArray.cpp:1049: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x000000003b545bab 10. ./build_docker/./src/Columns/ColumnConst.cpp:49: DB::ColumnConst::convertToFullColumn() const @ 0x000000003b652484 11. ./src/Columns/ColumnConst.h:41: DB::ColumnConst::convertToFullColumnIfConst() const @ 0x000000003b656c8e 12. ./build_docker/./src/Formats/NativeWriter.cpp:65: DB::NativeWriter::write(DB::Block const&) @ 0x000000003f6182bf 13. ./build_docker/./src/Server/TCPHandler.cpp:2458: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003f46f5a0 14. ./build_docker/./src/Server/TCPHandler.cpp:1260: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003f4514a7 15. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000003f42c464 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:48:59.945996 [ 6488 ] {67c9a22d-cc7a-4d10-9c55-73613de0e07c} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 8.00 GiB (attempt to allocate chunk of 8589803912 bytes), current RSS 14.25 MiB, maximum: 953.67 MiB. (MEMORY_LIMIT_EXCEEDED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43308) (comment: 01784_parallel_formatting_memory.sql) (in query: SELECT range(65535) FROM system.one ARRAY JOIN range(65536) AS number;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000207409d0 4. ./build_docker/./src/Common/MemoryTracker.cpp:322: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002073d3c1 5. ./build_docker/./src/Common/MemoryTracker.cpp:383: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002073c803 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:58: CurrentMemoryTracker::alloc(long) @ 0x000000002061ade9 7. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x0000000020616543 8. ./src/Common/PODArray.h:152: COW::immutable_ptr DB::ColumnArray::replicateNumber(DB::PODArray, 63ul, 64ul> const&) const @ 0x000000003b57a188 9. ./build_docker/./src/Columns/ColumnArray.cpp:1049: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x000000003b545bab 10. ./build_docker/./src/Columns/ColumnConst.cpp:49: DB::ColumnConst::convertToFullColumn() const @ 0x000000003b652484 11. ./src/Columns/ColumnConst.h:41: DB::ColumnConst::convertToFullColumnIfConst() const @ 0x000000003b656c8e 12. ./build_docker/./src/Formats/NativeWriter.cpp:65: DB::NativeWriter::write(DB::Block const&) @ 0x000000003f6182bf 13. ./build_docker/./src/Server/TCPHandler.cpp:2458: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003f46f5a0 14. ./build_docker/./src/Server/TCPHandler.cpp:1260: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003f4514a7 15. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000003f42c464 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:48:59.951951 [ 6488 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 8.00 GiB (attempt to allocate chunk of 8589803912 bytes), current RSS 14.25 MiB, maximum: 953.67 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000207409d0 4. ./build_docker/./src/Common/MemoryTracker.cpp:322: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002073d3c1 5. ./build_docker/./src/Common/MemoryTracker.cpp:383: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002073c803 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:58: CurrentMemoryTracker::alloc(long) @ 0x000000002061ade9 7. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x0000000020616543 8. ./src/Common/PODArray.h:152: COW::immutable_ptr DB::ColumnArray::replicateNumber(DB::PODArray, 63ul, 64ul> const&) const @ 0x000000003b57a188 9. ./build_docker/./src/Columns/ColumnArray.cpp:1049: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x000000003b545bab 10. ./build_docker/./src/Columns/ColumnConst.cpp:49: DB::ColumnConst::convertToFullColumn() const @ 0x000000003b652484 11. ./src/Columns/ColumnConst.h:41: DB::ColumnConst::convertToFullColumnIfConst() const @ 0x000000003b656c8e 12. ./build_docker/./src/Formats/NativeWriter.cpp:65: DB::NativeWriter::write(DB::Block const&) @ 0x000000003f6182bf 13. ./build_docker/./src/Server/TCPHandler.cpp:2458: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003f46f5a0 14. ./build_docker/./src/Server/TCPHandler.cpp:1260: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003f4514a7 15. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000003f42c464 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:49:00.315254 [ 6493 ] {51363f92-3072-4cf1-8415-a97cb5120fce} executeQuery: Code: 43. DB::Exception: subtractMilliseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') - toIntervalMillisecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43270) (comment: 01099_operators_date_and_timestamp.sql) (in query: select (date '2001-09-29' - interval 12345 millisecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000001bac38c5 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ba899c7 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000015f431f4 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001570eff9 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009f867c6 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 30. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 31. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 2025.04.02 01:49:00.318999 [ 6493 ] {} TCPHandler: Code: 43. DB::Exception: subtractMilliseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') - toIntervalMillisecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000001bac38c5 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ba899c7 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000015f431f4 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001570eff9 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009f867c6 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 30. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 31. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 2025.04.02 01:49:00.634178 [ 3093 ] {403dad97-7fe9-448f-af32-28d4909141c7} executeQuery: Code: 36. DB::Exception: The fourth argument of function seriesOutliersDetectTukey must be a non-negative number: In scope SELECT seriesOutliersDetectTukey([-3, 2, 15, 3, 5, 6, 4, 5, 12, 45, 12, 3, 3, 4, 5, 6], 0.25, 0.75, -1). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43314) (comment: 02813_seriesOutliersDetectTukey.sql) (in query: -- negative tests SELECT seriesOutliersDetectTukey([-3, 2, 15, 3, 5, 6, 4, 5, 12, 45, 12, 3, 3, 4, 5, 6], .25, .75, -1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. DB::FunctionSeriesOutliersDetectTukey::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b679ec1 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 27. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 28. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 2025.04.02 01:49:00.637525 [ 3093 ] {} TCPHandler: Code: 36. DB::Exception: The fourth argument of function seriesOutliersDetectTukey must be a non-negative number: In scope SELECT seriesOutliersDetectTukey([-3, 2, 15, 3, 5, 6, 4, 5, 12, 45, 12, 3, 3, 4, 5, 6], 0.25, 0.75, -1). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. DB::FunctionSeriesOutliersDetectTukey::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b679ec1 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 27. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 28. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 2025.04.02 01:49:01.189425 [ 6493 ] {03082e11-a119-421f-b502-e3b3d978e187} executeQuery: Code: 43. DB::Exception: subtractMicroseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') - toIntervalMicrosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43270) (comment: 01099_operators_date_and_timestamp.sql) (in query: select (date '2001-09-29' - interval 12345 microsecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000001ba86105 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ba4c207 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000015f431f4 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001570eff9 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009f867c6 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 30. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 31. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 2025.04.02 01:49:01.193063 [ 6493 ] {} TCPHandler: Code: 43. DB::Exception: subtractMicroseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') - toIntervalMicrosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000001ba86105 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ba4c207 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000015f431f4 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001570eff9 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009f867c6 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 30. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 31. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 2025.04.02 01:49:01.444235 [ 3093 ] {7a024644-abcf-4ee5-8e8f-1d92b7357a86} executeQuery: Code: 42. DB::Exception: Function seriesOutliersDetectTukey needs either 1 or 4 arguments; passed 3.: In scope SELECT seriesOutliersDetectTukey([-3, 2, 15, 3], 0.33, 0.53). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43314) (comment: 02813_seriesOutliersDetectTukey.sql) (in query: SELECT seriesOutliersDetectTukey([-3, 2, 15, 3], .33, .53);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000088ddead 4. DB::FunctionSeriesOutliersDetectTukey::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b67b29c 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:49:01.447392 [ 3093 ] {} TCPHandler: Code: 42. DB::Exception: Function seriesOutliersDetectTukey needs either 1 or 4 arguments; passed 3.: In scope SELECT seriesOutliersDetectTukey([-3, 2, 15, 3], 0.33, 0.53). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000088ddead 4. DB::FunctionSeriesOutliersDetectTukey::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b67b29c 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:49:01.463672 [ 3093 ] {272ab0ab-997b-4ce2-bf8b-f2e68a56edd6} executeQuery: Code: 42. DB::Exception: Function seriesOutliersDetectTukey needs either 1 or 4 arguments; passed 2.: In scope SELECT seriesOutliersDetectTukey([-3, 2, 15, 3], 0.33). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43314) (comment: 02813_seriesOutliersDetectTukey.sql) (in query: SELECT seriesOutliersDetectTukey([-3, 2, 15, 3], .33);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000088ddead 4. DB::FunctionSeriesOutliersDetectTukey::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b67b29c 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:49:01.466806 [ 3093 ] {} TCPHandler: Code: 42. DB::Exception: Function seriesOutliersDetectTukey needs either 1 or 4 arguments; passed 2.: In scope SELECT seriesOutliersDetectTukey([-3, 2, 15, 3], 0.33). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000088ddead 4. DB::FunctionSeriesOutliersDetectTukey::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b67b29c 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 31. ? @ 0x00007f583d9b1ac3 2025.04.02 01:49:02.059938 [ 6493 ] {5ec66114-14a1-4a76-8090-76dd7a4a858f} executeQuery: Code: 43. DB::Exception: subtractNanoseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') - toIntervalNanosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43270) (comment: 01099_operators_date_and_timestamp.sql) (in query: select (date '2001-09-29' - interval 12345 nanosecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000001bb7ad25 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000001bb3de87 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000015f431f4 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001570eff9 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009f867c6 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 30. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 31. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 2025.04.02 01:49:02.063715 [ 6493 ] {} TCPHandler: Code: 43. DB::Exception: subtractNanoseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') - toIntervalNanosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000001bb7ad25 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000001bb3de87 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000015f431f4 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001570eff9 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009f867c6 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 30. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 31. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 2025.04.02 01:49:02.272328 [ 3093 ] {d46fde5d-0652-4c1f-8380-27777edbb4b4} executeQuery: Code: 44. DB::Exception: Illegal column Array(Nullable(Float64)) of first argument of function seriesOutliersDetectTukey: In scope SELECT seriesOutliersDetectTukey([-3, 2.4, 15, NULL]). (ILLEGAL_COLUMN) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43314) (comment: 02813_seriesOutliersDetectTukey.sql) (in query: SELECT seriesOutliersDetectTukey([-3, 2.4, 15, NULL]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. DB::FunctionSeriesOutliersDetectTukey::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b67a14d 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 27. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 28. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 2025.04.02 01:49:02.276098 [ 3093 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column Array(Nullable(Float64)) of first argument of function seriesOutliersDetectTukey: In scope SELECT seriesOutliersDetectTukey([-3, 2.4, 15, NULL]). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. DB::FunctionSeriesOutliersDetectTukey::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b67a14d 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 27. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 28. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 2025.04.02 01:49:02.293852 [ 3093 ] {e7b0eb63-9220-45d7-b797-156a1228c592} executeQuery: Code: 44. DB::Exception: Illegal column Array(Nothing) of first argument of function seriesOutliersDetectTukey: In scope SELECT seriesOutliersDetectTukey([]). (ILLEGAL_COLUMN) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43314) (comment: 02813_seriesOutliersDetectTukey.sql) (in query: SELECT seriesOutliersDetectTukey([]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. DB::FunctionSeriesOutliersDetectTukey::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b67a14d 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 27. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 28. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 2025.04.02 01:49:02.296646 [ 3093 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column Array(Nothing) of first argument of function seriesOutliersDetectTukey: In scope SELECT seriesOutliersDetectTukey([]). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000088d192d 4. DB::FunctionSeriesOutliersDetectTukey::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b67a14d 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 27. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 28. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 2025.04.02 01:49:02.973792 [ 6493 ] {84b21027-a974-47d1-911c-8bc46b408618} executeQuery: Code: 43. DB::Exception: addMilliseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') + toIntervalMillisecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43270) (comment: 01099_operators_date_and_timestamp.sql) (in query: select (toDate32('2001-09-29') + interval 12345 millisecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000ae28f25 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000adf0a7f 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019b34b40 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001931d679 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009f867c6 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 30. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 31. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 2025.04.02 01:49:02.977267 [ 6493 ] {} TCPHandler: Code: 43. DB::Exception: addMilliseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') + toIntervalMillisecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000ae28f25 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000adf0a7f 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019b34b40 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001931d679 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009f867c6 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 30. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 31. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 2025.04.02 01:49:03.120492 [ 3093 ] {97cf57cf-6891-40c0-abbc-2af195e3d992} executeQuery: Code: 36. DB::Exception: At least four data points are needed for function seriesOutliersDetectTukey: In scope SELECT seriesOutliersDetectTukey([-3, 2.4, 15]). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43314) (comment: 02813_seriesOutliersDetectTukey.sql) (in query: SELECT seriesOutliersDetectTukey([-3, 2.4, 15]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. bool DB::FunctionSeriesOutliersDetectTukey::executeNumber(DB::IColumn const&, DB::PODArray, 63ul, 64ul> const&, double, double, double, COW::immutable_ptr&) const @ 0x000000001b68825c 5. DB::FunctionSeriesOutliersDetectTukey::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b6797c6 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:49:03.124124 [ 3093 ] {} TCPHandler: Code: 36. DB::Exception: At least four data points are needed for function seriesOutliersDetectTukey: In scope SELECT seriesOutliersDetectTukey([-3, 2.4, 15]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. bool DB::FunctionSeriesOutliersDetectTukey::executeNumber(DB::IColumn const&, DB::PODArray, 63ul, 64ul> const&, double, double, double, COW::immutable_ptr&) const @ 0x000000001b68825c 5. DB::FunctionSeriesOutliersDetectTukey::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b6797c6 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 2025.04.02 01:49:03.833927 [ 6493 ] {3dd9c8dd-c2f9-434e-97e7-c278f5b53109} executeQuery: Code: 43. DB::Exception: addMicroseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') + toIntervalMicrosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43270) (comment: 01099_operators_date_and_timestamp.sql) (in query: select (toDate32('2001-09-29') + interval 12345 microsecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000aded605 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000adb4b3f 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019b34b40 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001931d679 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009f867c6 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 30. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 31. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 2025.04.02 01:49:03.837967 [ 6493 ] {} TCPHandler: Code: 43. DB::Exception: addMicroseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') + toIntervalMicrosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000aded605 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000adb4b3f 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019b34b40 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001931d679 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009f867c6 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 30. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 31. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 2025.04.02 01:49:04.691515 [ 6493 ] {eca95549-2aca-47a9-bc66-6eecb44f5b39} executeQuery: Code: 43. DB::Exception: addNanoseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') + toIntervalNanosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43270) (comment: 01099_operators_date_and_timestamp.sql) (in query: select (toDate32('2001-09-29') + interval 12345 nanosecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000aee2e45 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aea395f 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019b34b40 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001931d679 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009f867c6 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 30. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 31. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 2025.04.02 01:49:04.695371 [ 6493 ] {} TCPHandler: Code: 43. DB::Exception: addNanoseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') + toIntervalNanosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000aee2e45 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aea395f 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019b34b40 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001931d679 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009f867c6 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 30. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 31. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 2025.04.02 01:49:05.607356 [ 6493 ] {59bcb492-c244-4ec4-abef-63cb849fa99e} executeQuery: Code: 43. DB::Exception: subtractMilliseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') - toIntervalMillisecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43270) (comment: 01099_operators_date_and_timestamp.sql) (in query: select (toDate32('2001-09-29') - interval 12345 millisecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000001bac3d85 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ba89a3f 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000015f431f4 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001570eff9 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009f867c6 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 30. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 31. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 2025.04.02 01:49:05.610597 [ 6493 ] {} TCPHandler: Code: 43. DB::Exception: subtractMilliseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') - toIntervalMillisecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000001bac3d85 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ba89a3f 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000015f431f4 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001570eff9 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009f867c6 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 30. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 31. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 2025.04.02 01:49:06.467287 [ 6493 ] {cde7220a-61ef-4bc8-963f-6124277b7862} executeQuery: Code: 43. DB::Exception: subtractMicroseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') - toIntervalMicrosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43270) (comment: 01099_operators_date_and_timestamp.sql) (in query: select (toDate32('2001-09-29') - interval 12345 microsecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000001ba865c5 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ba4c27f 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000015f431f4 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001570eff9 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009f867c6 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 30. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 31. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 2025.04.02 01:49:06.472895 [ 6493 ] {} TCPHandler: Code: 43. DB::Exception: subtractMicroseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') - toIntervalMicrosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000001ba865c5 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ba4c27f 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000015f431f4 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001570eff9 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009f867c6 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 30. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 31. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 2025.04.02 01:49:07.348325 [ 6493 ] {e8147243-499f-4be8-a100-e85aa1348d3e} executeQuery: Code: 43. DB::Exception: subtractNanoseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') - toIntervalNanosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:43270) (comment: 01099_operators_date_and_timestamp.sql) (in query: select (toDate32('2001-09-29') - interval 12345 nanosecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000001bb7b1e5 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000001bb3deff 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000015f431f4 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001570eff9 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009f867c6 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 30. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 31. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 2025.04.02 01:49:07.352107 [ 6493 ] {} TCPHandler: Code: 43. DB::Exception: subtractNanoseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') - toIntervalNanosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000001bb7b1e5 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000001bb3deff 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000015f431f4 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001570eff9 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009f867c6 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 30. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 31. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 2025.04.02 01:49:13.181581 [ 3076 ] {0a1a2299-15a0-412f-ab79-96e6a7fd63e0} executeQuery: Code: 43. DB::Exception: Illegal types Array(UInt8) and Array(UInt8) of arguments of function modulo: In scope SELECT [12, 13] % [5, 6]. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:35898) (comment: 02812_pointwise_array_operations.sql) (in query: SELECT ([12,13] % [5,6]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008b276d7 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000016a542e0 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000015ff10f9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009f867c6 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:49:13.185685 [ 3076 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Array(UInt8) and Array(UInt8) of arguments of function modulo: In scope SELECT [12, 13] % [5, 6]. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008b276d7 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000016a542e0 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000015ff10f9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009f867c6 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 2025.04.02 01:49:14.026293 [ 3076 ] {3d1194fa-29be-421a-bf1b-051aa9ca05b1} executeQuery: Code: 190. DB::Exception: Two arguments for function minus must have equal sizes: In scope SELECT [2, 3, 4] - [1, -2, 10, 29]. (SIZES_OF_ARRAYS_DONT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:35898) (comment: 02812_pointwise_array_operations.sql) (in query: SELECT ([2,3,4]-[1,-2,10,29]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015b68182 5. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000015b5a805 6. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015b5397d 7. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015b4f219 8. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015b65a87 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000015b5a805 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015b5397d 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015b4f219 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 2025.04.02 01:49:14.030046 [ 3076 ] {} TCPHandler: Code: 190. DB::Exception: Two arguments for function minus must have equal sizes: In scope SELECT [2, 3, 4] - [1, -2, 10, 29]. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015b68182 5. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000015b5a805 6. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015b5397d 7. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015b4f219 8. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015b65a87 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000015b5a805 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015b5397d 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015b4f219 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 2025.04.02 01:49:14.619992 [ 3076 ] {8db8fc7a-46cd-4468-99a7-807da45ed09b} executeQuery: Code: 190. DB::Exception: Two arguments for function plus must have equal sizes: while executing 'FUNCTION plus(__table1.x :: 2, __table1.y : 0) -> plus(__table1.x, __table1.y) Array(UInt64) : 3'. (SIZES_OF_ARRAYS_DONT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:35898) (comment: 02812_pointwise_array_operations.sql) (in query: SELECT x, y, x+y FROM a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001973f382 5. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000019731a05 6. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001972a350 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x00000000400e3001 13. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027d13b04 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003f6df04b 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003f71c8c3 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c2f5 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:49:14.624726 [ 3076 ] {} TCPHandler: Code: 190. DB::Exception: Two arguments for function plus must have equal sizes: while executing 'FUNCTION plus(__table1.x :: 2, __table1.y : 0) -> plus(__table1.x, __table1.y) Array(UInt64) : 3'. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001973f382 5. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000019731a05 6. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001972a350 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x00000000400e3001 13. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027d13b04 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003f6df04b 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003f71c8c3 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c2f5 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:49:15.893793 [ 1053 ] {7f896808-18be-4928-8566-283d8fad81c6::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:49:16.751532 [ 1053 ] {7f896808-18be-4928-8566-283d8fad81c6::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001b8168d7 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001b81651c 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b814c91 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 11. ./build_docker/./src/Columns/ColumnFunction.cpp:350: DB::ColumnFunction::reduce() const @ 0x000000003b9a0f20 12. ./build_docker/./src/Columns/ColumnFunction.cpp:339: DB::ColumnFunction::reduce() const @ 0x000000003b9a01bb 13. ./build_docker/./src/Columns/MaskOperations.cpp:283: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x000000003c690776 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000037a269e6 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x00000000400e3001 21. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027d13b04 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003f6df04b 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762e32 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1222: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000003e665e75 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1136: DB::PartMergerWriter::execute() @ 0x000000003e6d3c93 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1369: DB::MutateAllPartColumnsTask::executeStep() @ 0x000000003e6c31f2 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2002: DB::MutateTask::execute() @ 0x000000003e67277f (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:49:16.752347 [ 1053 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7f896808-18be-4928-8566-283d8fad81c6::1_1_1_0_3}: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001b8168d7 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001b81651c 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b814c91 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 11. ./build_docker/./src/Columns/ColumnFunction.cpp:350: DB::ColumnFunction::reduce() const @ 0x000000003b9a0f20 12. ./build_docker/./src/Columns/ColumnFunction.cpp:339: DB::ColumnFunction::reduce() const @ 0x000000003b9a01bb 13. ./build_docker/./src/Columns/MaskOperations.cpp:283: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x000000003c690776 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000037a269e6 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x00000000400e3001 21. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027d13b04 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003f6df04b 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762e32 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1222: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000003e665e75 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1136: DB::PartMergerWriter::execute() @ 0x000000003e6d3c93 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1369: DB::MutateAllPartColumnsTask::executeStep() @ 0x000000003e6c31f2 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2002: DB::MutateTask::execute() @ 0x000000003e67277f (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:49:16.952399 [ 1054 ] {7f896808-18be-4928-8566-283d8fad81c6::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:49:16.953348 [ 1054 ] {7f896808-18be-4928-8566-283d8fad81c6::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001b8168d7 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001b81651c 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b814c91 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 11. ./build_docker/./src/Columns/ColumnFunction.cpp:350: DB::ColumnFunction::reduce() const @ 0x000000003b9a0f20 12. ./build_docker/./src/Columns/ColumnFunction.cpp:339: DB::ColumnFunction::reduce() const @ 0x000000003b9a01bb 13. ./build_docker/./src/Columns/MaskOperations.cpp:283: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x000000003c690776 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000037a269e6 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x00000000400e3001 21. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027d13b04 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003f6df04b 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762e32 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1222: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000003e665e75 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1136: DB::PartMergerWriter::execute() @ 0x000000003e6d3c93 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1369: DB::MutateAllPartColumnsTask::executeStep() @ 0x000000003e6c31f2 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2002: DB::MutateTask::execute() @ 0x000000003e67277f (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:49:16.954228 [ 1054 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7f896808-18be-4928-8566-283d8fad81c6::1_1_1_0_3}: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001b8168d7 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001b81651c 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b814c91 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 11. ./build_docker/./src/Columns/ColumnFunction.cpp:350: DB::ColumnFunction::reduce() const @ 0x000000003b9a0f20 12. ./build_docker/./src/Columns/ColumnFunction.cpp:339: DB::ColumnFunction::reduce() const @ 0x000000003b9a01bb 13. ./build_docker/./src/Columns/MaskOperations.cpp:283: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x000000003c690776 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000037a269e6 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x00000000400e3001 21. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027d13b04 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003f6df04b 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762e32 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1222: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000003e665e75 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1136: DB::PartMergerWriter::execute() @ 0x000000003e6d3c93 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1369: DB::MutateAllPartColumnsTask::executeStep() @ 0x000000003e6c31f2 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2002: DB::MutateTask::execute() @ 0x000000003e67277f (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:49:17.323842 [ 1052 ] {7f896808-18be-4928-8566-283d8fad81c6::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:49:17.324911 [ 1052 ] {7f896808-18be-4928-8566-283d8fad81c6::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001b8168d7 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001b81651c 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b814c91 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 11. ./build_docker/./src/Columns/ColumnFunction.cpp:350: DB::ColumnFunction::reduce() const @ 0x000000003b9a0f20 12. ./build_docker/./src/Columns/ColumnFunction.cpp:339: DB::ColumnFunction::reduce() const @ 0x000000003b9a01bb 13. ./build_docker/./src/Columns/MaskOperations.cpp:283: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x000000003c690776 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000037a269e6 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x00000000400e3001 21. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027d13b04 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003f6df04b 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762e32 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1222: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000003e665e75 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1136: DB::PartMergerWriter::execute() @ 0x000000003e6d3c93 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1369: DB::MutateAllPartColumnsTask::executeStep() @ 0x000000003e6c31f2 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2002: DB::MutateTask::execute() @ 0x000000003e67277f (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:49:17.325841 [ 1052 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7f896808-18be-4928-8566-283d8fad81c6::1_1_1_0_3}: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001b8168d7 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001b81651c 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b814c91 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 11. ./build_docker/./src/Columns/ColumnFunction.cpp:350: DB::ColumnFunction::reduce() const @ 0x000000003b9a0f20 12. ./build_docker/./src/Columns/ColumnFunction.cpp:339: DB::ColumnFunction::reduce() const @ 0x000000003b9a01bb 13. ./build_docker/./src/Columns/MaskOperations.cpp:283: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x000000003c690776 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000037a269e6 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x00000000400e3001 21. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027d13b04 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003f6df04b 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762e32 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1222: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000003e665e75 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1136: DB::PartMergerWriter::execute() @ 0x000000003e6d3c93 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1369: DB::MutateAllPartColumnsTask::executeStep() @ 0x000000003e6c31f2 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2002: DB::MutateTask::execute() @ 0x000000003e67277f (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:49:18.028456 [ 1059 ] {7f896808-18be-4928-8566-283d8fad81c6::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:49:18.029441 [ 1059 ] {7f896808-18be-4928-8566-283d8fad81c6::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001b8168d7 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001b81651c 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b814c91 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 11. ./build_docker/./src/Columns/ColumnFunction.cpp:350: DB::ColumnFunction::reduce() const @ 0x000000003b9a0f20 12. ./build_docker/./src/Columns/ColumnFunction.cpp:339: DB::ColumnFunction::reduce() const @ 0x000000003b9a01bb 13. ./build_docker/./src/Columns/MaskOperations.cpp:283: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x000000003c690776 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000037a269e6 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x00000000400e3001 21. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027d13b04 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003f6df04b 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762e32 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1222: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000003e665e75 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1136: DB::PartMergerWriter::execute() @ 0x000000003e6d3c93 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1369: DB::MutateAllPartColumnsTask::executeStep() @ 0x000000003e6c31f2 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2002: DB::MutateTask::execute() @ 0x000000003e67277f (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:49:18.030232 [ 1059 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7f896808-18be-4928-8566-283d8fad81c6::1_1_1_0_3}: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001b8168d7 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001b81651c 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b814c91 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 11. ./build_docker/./src/Columns/ColumnFunction.cpp:350: DB::ColumnFunction::reduce() const @ 0x000000003b9a0f20 12. ./build_docker/./src/Columns/ColumnFunction.cpp:339: DB::ColumnFunction::reduce() const @ 0x000000003b9a01bb 13. ./build_docker/./src/Columns/MaskOperations.cpp:283: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x000000003c690776 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000037a269e6 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x00000000400e3001 21. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027d13b04 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003f6df04b 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762e32 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1222: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000003e665e75 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1136: DB::PartMergerWriter::execute() @ 0x000000003e6d3c93 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1369: DB::MutateAllPartColumnsTask::executeStep() @ 0x000000003e6c31f2 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2002: DB::MutateTask::execute() @ 0x000000003e67277f (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:49:18.497979 [ 6498 ] {024d844d-66e3-4f6d-b309-4e646f0f110a} executeQuery: Code: 36. DB::Exception: Too many groups for analysis of variance (should be no more than 1048576, got 18446744073709551615): While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:36108) (comment: 02874_analysis_of_variance_overflow.sql) (in query: SELECT analysisOfVariance(1, 18446744073709551615);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long&) @ 0x00000000089055ad 4. ./src/AggregateFunctions/Moments.h:463: DB::AnalysisOfVarianceMoments::add(double, unsigned long) @ 0x0000000027088654 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionAnalysisOfVariance.cpp:59: DB::IAggregateFunctionHelper::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000270852aa 6. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeWithoutKeyImpl(char*&, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, DB::Arena*, bool) const @ 0x0000000036a701ad 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1562: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000036a77b14 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000040084b96 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000040078368 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003f71c8c3 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c2f5 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 17. ? @ 0x00007f583d9b1ac3 18. ? @ 0x00007f583da43850 2025.04.02 01:49:18.504088 [ 6498 ] {} TCPHandler: Code: 36. DB::Exception: Too many groups for analysis of variance (should be no more than 1048576, got 18446744073709551615): While executing AggregatingTransform. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long&) @ 0x00000000089055ad 4. ./src/AggregateFunctions/Moments.h:463: DB::AnalysisOfVarianceMoments::add(double, unsigned long) @ 0x0000000027088654 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionAnalysisOfVariance.cpp:59: DB::IAggregateFunctionHelper::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000270852aa 6. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeWithoutKeyImpl(char*&, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, DB::Arena*, bool) const @ 0x0000000036a701ad 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1562: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000036a77b14 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000040084b96 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000040078368 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003f71c8c3 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c2f5 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f7606ca 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 17. ? @ 0x00007f583d9b1ac3 18. ? @ 0x00007f583da43850 2025.04.02 01:49:18.770464 [ 1060 ] {7f896808-18be-4928-8566-283d8fad81c6::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:49:18.771358 [ 1060 ] {7f896808-18be-4928-8566-283d8fad81c6::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001b8168d7 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001b81651c 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b814c91 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 11. ./build_docker/./src/Columns/ColumnFunction.cpp:350: DB::ColumnFunction::reduce() const @ 0x000000003b9a0f20 12. ./build_docker/./src/Columns/ColumnFunction.cpp:339: DB::ColumnFunction::reduce() const @ 0x000000003b9a01bb 13. ./build_docker/./src/Columns/MaskOperations.cpp:283: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x000000003c690776 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000037a269e6 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x00000000400e3001 21. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027d13b04 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003f6df04b 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762e32 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1222: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000003e665e75 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1136: DB::PartMergerWriter::execute() @ 0x000000003e6d3c93 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1369: DB::MutateAllPartColumnsTask::executeStep() @ 0x000000003e6c31f2 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2002: DB::MutateTask::execute() @ 0x000000003e67277f (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:49:18.772055 [ 1060 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7f896808-18be-4928-8566-283d8fad81c6::1_1_1_0_3}: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001b8168d7 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001b81651c 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b814c91 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 11. ./build_docker/./src/Columns/ColumnFunction.cpp:350: DB::ColumnFunction::reduce() const @ 0x000000003b9a0f20 12. ./build_docker/./src/Columns/ColumnFunction.cpp:339: DB::ColumnFunction::reduce() const @ 0x000000003b9a01bb 13. ./build_docker/./src/Columns/MaskOperations.cpp:283: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x000000003c690776 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000037a269e6 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x00000000400e3001 21. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027d13b04 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003f6df04b 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762e32 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1222: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000003e665e75 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1136: DB::PartMergerWriter::execute() @ 0x000000003e6d3c93 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1369: DB::MutateAllPartColumnsTask::executeStep() @ 0x000000003e6c31f2 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2002: DB::MutateTask::execute() @ 0x000000003e67277f (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:49:19.146492 [ 1055 ] {7f896808-18be-4928-8566-283d8fad81c6::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:49:19.147470 [ 1055 ] {7f896808-18be-4928-8566-283d8fad81c6::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001b8168d7 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001b81651c 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b814c91 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 11. ./build_docker/./src/Columns/ColumnFunction.cpp:350: DB::ColumnFunction::reduce() const @ 0x000000003b9a0f20 12. ./build_docker/./src/Columns/ColumnFunction.cpp:339: DB::ColumnFunction::reduce() const @ 0x000000003b9a01bb 13. ./build_docker/./src/Columns/MaskOperations.cpp:283: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x000000003c690776 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000037a269e6 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x00000000400e3001 21. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027d13b04 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003f6df04b 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762e32 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1222: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000003e665e75 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1136: DB::PartMergerWriter::execute() @ 0x000000003e6d3c93 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1369: DB::MutateAllPartColumnsTask::executeStep() @ 0x000000003e6c31f2 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2002: DB::MutateTask::execute() @ 0x000000003e67277f (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:49:19.148304 [ 1055 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7f896808-18be-4928-8566-283d8fad81c6::1_1_1_0_3}: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001b8168d7 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001b81651c 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b814c91 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 11. ./build_docker/./src/Columns/ColumnFunction.cpp:350: DB::ColumnFunction::reduce() const @ 0x000000003b9a0f20 12. ./build_docker/./src/Columns/ColumnFunction.cpp:339: DB::ColumnFunction::reduce() const @ 0x000000003b9a01bb 13. ./build_docker/./src/Columns/MaskOperations.cpp:283: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x000000003c690776 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000037a269e6 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x00000000400e3001 21. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027d13b04 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003f6df04b 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762e32 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1222: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000003e665e75 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1136: DB::PartMergerWriter::execute() @ 0x000000003e6d3c93 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1369: DB::MutateAllPartColumnsTask::executeStep() @ 0x000000003e6c31f2 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2002: DB::MutateTask::execute() @ 0x000000003e67277f (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:49:19.431710 [ 1053 ] {7f896808-18be-4928-8566-283d8fad81c6::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:49:19.432551 [ 1053 ] {7f896808-18be-4928-8566-283d8fad81c6::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001b8168d7 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001b81651c 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b814c91 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 11. ./build_docker/./src/Columns/ColumnFunction.cpp:350: DB::ColumnFunction::reduce() const @ 0x000000003b9a0f20 12. ./build_docker/./src/Columns/ColumnFunction.cpp:339: DB::ColumnFunction::reduce() const @ 0x000000003b9a01bb 13. ./build_docker/./src/Columns/MaskOperations.cpp:283: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x000000003c690776 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000037a269e6 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x00000000400e3001 21. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027d13b04 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003f6df04b 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762e32 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1222: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000003e665e75 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1136: DB::PartMergerWriter::execute() @ 0x000000003e6d3c93 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1369: DB::MutateAllPartColumnsTask::executeStep() @ 0x000000003e6c31f2 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2002: DB::MutateTask::execute() @ 0x000000003e67277f (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:49:19.433316 [ 1053 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7f896808-18be-4928-8566-283d8fad81c6::1_1_1_0_3}: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001b8168d7 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001b81651c 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b814c91 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 11. ./build_docker/./src/Columns/ColumnFunction.cpp:350: DB::ColumnFunction::reduce() const @ 0x000000003b9a0f20 12. ./build_docker/./src/Columns/ColumnFunction.cpp:339: DB::ColumnFunction::reduce() const @ 0x000000003b9a01bb 13. ./build_docker/./src/Columns/MaskOperations.cpp:283: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x000000003c690776 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000037a269e6 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x00000000400e3001 21. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027d13b04 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003f6df04b 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762e32 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1222: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000003e665e75 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1136: DB::PartMergerWriter::execute() @ 0x000000003e6d3c93 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1369: DB::MutateAllPartColumnsTask::executeStep() @ 0x000000003e6c31f2 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2002: DB::MutateTask::execute() @ 0x000000003e67277f (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:49:19.726706 [ 1054 ] {7f896808-18be-4928-8566-283d8fad81c6::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:49:19.727558 [ 1054 ] {7f896808-18be-4928-8566-283d8fad81c6::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001b8168d7 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001b81651c 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b814c91 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 11. ./build_docker/./src/Columns/ColumnFunction.cpp:350: DB::ColumnFunction::reduce() const @ 0x000000003b9a0f20 12. ./build_docker/./src/Columns/ColumnFunction.cpp:339: DB::ColumnFunction::reduce() const @ 0x000000003b9a01bb 13. ./build_docker/./src/Columns/MaskOperations.cpp:283: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x000000003c690776 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000037a269e6 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x00000000400e3001 21. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027d13b04 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003f6df04b 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762e32 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1222: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000003e665e75 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1136: DB::PartMergerWriter::execute() @ 0x000000003e6d3c93 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1369: DB::MutateAllPartColumnsTask::executeStep() @ 0x000000003e6c31f2 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2002: DB::MutateTask::execute() @ 0x000000003e67277f (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:49:19.728209 [ 1054 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7f896808-18be-4928-8566-283d8fad81c6::1_1_1_0_3}: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001b8168d7 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001b81651c 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b814c91 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfe7ff 11. ./build_docker/./src/Columns/ColumnFunction.cpp:350: DB::ColumnFunction::reduce() const @ 0x000000003b9a0f20 12. ./build_docker/./src/Columns/ColumnFunction.cpp:339: DB::ColumnFunction::reduce() const @ 0x000000003b9a01bb 13. ./build_docker/./src/Columns/MaskOperations.cpp:283: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x000000003c690776 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000037a269e6 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x00000000400e3001 21. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027d13b04 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003f6df04b 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762e32 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1222: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000003e665e75 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1136: DB::PartMergerWriter::execute() @ 0x000000003e6d3c93 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1369: DB::MutateAllPartColumnsTask::executeStep() @ 0x000000003e6c31f2 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2002: DB::MutateTask::execute() @ 0x000000003e67277f (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:49:35.502568 [ 6484 ] {6f31af26-7c46-460d-9177-d7e8670e5092} executeQuery: Code: 469. DB::Exception: Constraint `check_sign_column` for table test_s8a0lzcl.collapsing_merge_tree (8be574ba-2554-40a3-ad5c-37020ffa1e2e) is violated at row 1. Expression: (Sign IN [-1, 1]). Column values: Sign = 5. (VIOLATED_CONSTRAINT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:36402) (comment: 02918_implicit_sign_column_constraints_for_collapsing_engine.sh) (in query: INSERT INTO collapsing_merge_tree VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000034f78a67 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x00000000400aa208 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x00000000400e14d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000400e0ff6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x00000000400dfcc7 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003f76f0ba 12. ./build_docker/./src/Server/TCPHandler.cpp:1122: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003f44ec83 13. ./build_docker/./src/Server/TCPHandler.cpp:665: DB::TCPHandler::runImpl() @ 0x000000003f42c409 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 20. ? @ 0x00007f583d9b1ac3 21. ? @ 0x00007f583da43850 2025.04.02 01:49:35.509488 [ 6484 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `check_sign_column` for table test_s8a0lzcl.collapsing_merge_tree (8be574ba-2554-40a3-ad5c-37020ffa1e2e) is violated at row 1. Expression: (Sign IN [-1, 1]). Column values: Sign = 5. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000034f78a67 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x00000000400aa208 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x00000000400e14d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000400e0ff6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x00000000400dfcc7 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003f76f0ba 12. ./build_docker/./src/Server/TCPHandler.cpp:1122: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003f44ec83 13. ./build_docker/./src/Server/TCPHandler.cpp:665: DB::TCPHandler::runImpl() @ 0x000000003f42c409 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 20. ? @ 0x00007f583d9b1ac3 21. ? @ 0x00007f583da43850 2025.04.02 01:49:37.793295 [ 423 ] {94ca2ec8-4dbc-4bf0-b4b9-8b9b33a13295} DynamicQueryHandler: Code: 271. DB::Exception: Invalid zero byte count(s): 5 and 1. (CANNOT_DECOMPRESS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::CompressionCodecFPC::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x0000000042269eaf 4. ./build_docker/./src/Compression/ICompressionCodec.cpp:120: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x0000000042285eb3 5. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:317: DB::CompressedReadBufferBase::decompress(DB::BufferBase::Buffer&, unsigned long, unsigned long) @ 0x0000000042150ecf 6. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:24: non-virtual thunk to DB::CompressedReadBuffer::nextImpl() @ 0x000000004214b726 7. DB::ReadBuffer::next() @ 0x0000000008c442cf 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x0000000033794426 9. DB::ReadBuffer::next() @ 0x0000000008c442cf 10. ./src/IO/ReadBuffer.h:103: DB::ConcatReadBuffer::nextImpl() @ 0x0000000036438fd7 11. DB::ReadBuffer::next() @ 0x0000000008c442cf 12. ./src/IO/ReadBuffer.h:88: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000039287abd 13. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003f279970 14. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003f285729 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003f4a8b63 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 21. ? @ 0x00007f583d9b1ac3 22. ? @ 0x00007f583da43850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:49:38.218895 [ 6498 ] {d6d56e12-b7aa-423d-9163-d8fa134af362} DynamicQueryHandler: Code: 271. DB::Exception: Invalid zero byte count(s): 1 and 6. (CANNOT_DECOMPRESS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::CompressionCodecFPC::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x0000000042269eaf 4. ./build_docker/./src/Compression/ICompressionCodec.cpp:120: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x0000000042285eb3 5. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:317: DB::CompressedReadBufferBase::decompress(DB::BufferBase::Buffer&, unsigned long, unsigned long) @ 0x0000000042150ecf 6. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:24: non-virtual thunk to DB::CompressedReadBuffer::nextImpl() @ 0x000000004214b726 7. DB::ReadBuffer::next() @ 0x0000000008c442cf 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x0000000033794426 9. DB::ReadBuffer::next() @ 0x0000000008c442cf 10. ./src/IO/ReadBuffer.h:103: DB::ConcatReadBuffer::nextImpl() @ 0x0000000036438fd7 11. DB::ReadBuffer::next() @ 0x0000000008c442cf 12. ./src/IO/ReadBuffer.h:88: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000039287abd 13. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003f279970 14. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003f285729 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003f4a8b63 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 21. ? @ 0x00007f583d9b1ac3 22. ? @ 0x00007f583da43850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:49:40.349714 [ 423 ] {28b0431c-2490-4ea9-a351-9caa0e01993a} executeQuery: Code: 469. DB::Exception: Constraint `check_sign_column` for table test_s8a0lzcl.versioned_collapsing_merge_tree (b26f3e40-0c0f-4205-8d12-014922d55bf6) is violated at row 1. Expression: (Sign IN [-1, 1]). Column values: Sign = 5. (VIOLATED_CONSTRAINT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42506) (comment: 02918_implicit_sign_column_constraints_for_collapsing_engine.sh) (in query: INSERT INTO versioned_collapsing_merge_tree VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000034f78a67 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x00000000400aa208 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x00000000400e14d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000400e0ff6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x00000000400dfcc7 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003f76f0ba 12. ./build_docker/./src/Server/TCPHandler.cpp:1122: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003f44ec83 13. ./build_docker/./src/Server/TCPHandler.cpp:665: DB::TCPHandler::runImpl() @ 0x000000003f42c409 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 20. ? @ 0x00007f583d9b1ac3 21. ? @ 0x00007f583da43850 2025.04.02 01:49:40.355803 [ 423 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `check_sign_column` for table test_s8a0lzcl.versioned_collapsing_merge_tree (b26f3e40-0c0f-4205-8d12-014922d55bf6) is violated at row 1. Expression: (Sign IN [-1, 1]). Column values: Sign = 5. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000034f78a67 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x00000000400aa208 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x00000000400e14d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000400e0ff6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x00000000400dfcc7 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003f76f0ba 12. ./build_docker/./src/Server/TCPHandler.cpp:1122: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003f44ec83 13. ./build_docker/./src/Server/TCPHandler.cpp:665: DB::TCPHandler::runImpl() @ 0x000000003f42c409 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 20. ? @ 0x00007f583d9b1ac3 21. ? @ 0x00007f583da43850 2025.04.02 01:49:40.626467 [ 7799 ] {9960ced0-0956-4fa9-9c0d-d6227b2bb60f} executeQuery: Code: 6. DB::Exception: Cannot parse ignore_data_skipping_indices (''). (CANNOT_PARSE_TEXT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:36566) (comment: 02771_ignore_data_skipping_indices.sql) (in query: SELECT * FROM data_02771 SETTINGS ignore_data_skipping_indices='';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ac716ea 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1575: DB::buildIndexes(std::optional&, DB::ActionsDAG const*, DB::MergeTreeData const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000004089d837 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1672: DB::ReadFromMergeTree::applyFilters(DB::ActionDAGNodes) @ 0x00000000408967e7 6. ./src/Processors/QueryPlan/SourceStepWithFilter.h:65: DB::SourceStepWithFilter::applyFilters() @ 0x0000000040b110c7 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:55: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x0000000040b10a1f 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:118: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000040ab2602 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:471: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000040817d9e 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000038646949 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:228: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000386462e1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 14. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 15. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 21. ? @ 0x00007f583d9b1ac3 22. ? @ 0x00007f583da43850 2025.04.02 01:49:40.629741 [ 7799 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse ignore_data_skipping_indices (''). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ac716ea 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1575: DB::buildIndexes(std::optional&, DB::ActionsDAG const*, DB::MergeTreeData const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000004089d837 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1672: DB::ReadFromMergeTree::applyFilters(DB::ActionDAGNodes) @ 0x00000000408967e7 6. ./src/Processors/QueryPlan/SourceStepWithFilter.h:65: DB::SourceStepWithFilter::applyFilters() @ 0x0000000040b110c7 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:55: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x0000000040b10a1f 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:118: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000040ab2602 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:471: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000040817d9e 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000038646949 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:228: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000386462e1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 14. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 15. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 21. ? @ 0x00007f583d9b1ac3 22. ? @ 0x00007f583da43850 2025.04.02 01:49:41.413458 [ 7799 ] {5b681e46-8abd-4467-bdb4-7c5970d0af20} executeQuery: Code: 277. DB::Exception: Index `xy_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:36566) (comment: 02771_ignore_data_skipping_indices.sql) (in query: SELECT * FROM data_02771 WHERE x = 1 AND y = 1 SETTINGS ignore_data_skipping_indices='xy_idx',force_data_skipping_indices='xy_idx' ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:670: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x000000003e1d7b98 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1778: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x00000000408936d9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1492: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000004088f1a8 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1487: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000004088e945 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1964: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000408a7df9 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2073: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000408ad466 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000004079a755 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000004081866f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000038646949 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:228: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000386462e1 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 16. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 17. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 23. ? @ 0x00007f583d9b1ac3 24. ? @ 0x00007f583da43850 2025.04.02 01:49:41.417104 [ 7799 ] {} TCPHandler: Code: 277. DB::Exception: Index `xy_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:670: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x000000003e1d7b98 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1778: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x00000000408936d9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1492: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000004088f1a8 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1487: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000004088e945 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1964: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000408a7df9 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2073: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000408ad466 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000004079a755 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000004081866f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000038646949 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:228: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000386462e1 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 16. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 17. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 23. ? @ 0x00007f583d9b1ac3 24. ? @ 0x00007f583da43850 2025.04.02 01:49:52.553692 [ 7799 ] {52b782be-a7dd-4a7f-93d1-ca9a48bd4b6f} executeQuery: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 3, should be 1: In scope SELECT BLAKE3(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT BLAKE3(NULL, NULL, NULL);) 2025.04.02 01:49:52.576826 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 3, should be 1: In scope SELECT BLAKE3(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:52.656514 [ 7799 ] {d3e80578-1272-46b7-8809-ebb2ecff1841} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHARACTER_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT CHARACTER_LENGTH(NULL, NULL, NULL);) 2025.04.02 01:49:52.692082 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHARACTER_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:52.715023 [ 7799 ] {e8623c80-5426-4abd-ac71-e6378887c6bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHAR_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT CHAR_LENGTH(NULL, NULL, NULL);) 2025.04.02 01:49:52.744045 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHAR_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:53.006425 [ 7799 ] {1eb45e08-b55d-473a-85e0-4a5f9911b81b} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 3, should be 1: In scope SELECT CRC32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT CRC32(NULL, NULL, NULL);) 2025.04.02 01:49:53.017714 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 3, should be 1: In scope SELECT CRC32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:53.050413 [ 7799 ] {dd381d2b-70b7-4db8-9738-b1259cfd9036} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 3, should be 1: In scope SELECT CRC32IEEE(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT CRC32IEEE(NULL, NULL, NULL);) 2025.04.02 01:49:53.055912 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 3, should be 1: In scope SELECT CRC32IEEE(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:53.082137 [ 7799 ] {4e179e18-dd44-4d85-a709-b956686d8692} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 3, should be 1: In scope SELECT CRC64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT CRC64(NULL, NULL, NULL);) 2025.04.02 01:49:53.088059 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 3, should be 1: In scope SELECT CRC64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:53.118246 [ 7799 ] {6f875503-5c0d-4841-ae16-8c77d1c59688} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT DATABASE(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT DATABASE(NULL, NULL, NULL);) 2025.04.02 01:49:53.126426 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT DATABASE(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:53.778587 [ 7799 ] {5d9f95f8-1386-4a01-b0e1-32b82b762483} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT FORMAT_BYTES(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT FORMAT_BYTES(NULL, NULL, NULL);) 2025.04.02 01:49:53.787653 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT FORMAT_BYTES(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:53.818578 [ 7799 ] {69ce0010-d049-49cd-b610-9558037c579a} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT FQDN(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT FQDN(NULL, NULL, NULL);) 2025.04.02 01:49:53.834679 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT FQDN(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:53.867818 [ 7799 ] {affcc3cc-7889-4afa-8543-82d256863138} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT FROM_BASE64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT FROM_BASE64(NULL, NULL, NULL);) 2025.04.02 01:49:53.885064 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT FROM_BASE64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:53.918958 [ 7799 ] {4904a232-4ae5-4c90-a79e-55b2b54f4414} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT FROM_DAYS(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT FROM_DAYS(NULL, NULL, NULL);) 2025.04.02 01:49:53.949106 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT FROM_DAYS(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:54.238792 [ 7799 ] {a2e71bb2-1bce-4f0f-8115-2c300d1d9b67} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET6_ATON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT INET6_ATON(NULL, NULL, NULL);) 2025.04.02 01:49:54.243566 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET6_ATON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:54.286031 [ 7799 ] {1afa8d13-9de1-4910-9fa8-71d92215da7e} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT INET6_NTOA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT INET6_NTOA(NULL, NULL, NULL);) 2025.04.02 01:49:54.312320 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT INET6_NTOA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:54.349294 [ 7799 ] {785574bf-d7e1-45b4-94f5-65e4c860566e} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET_ATON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT INET_ATON(NULL, NULL, NULL);) 2025.04.02 01:49:54.358922 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET_ATON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:54.385284 [ 7799 ] {2f02a7af-e143-42a0-8ad5-084d813bf9b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT INET_NTOA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT INET_NTOA(NULL, NULL, NULL);) 2025.04.02 01:49:54.393056 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT INET_NTOA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:54.419314 [ 7799 ] {81c59290-a0a1-4209-812a-d117eb6ee38a} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv4CIDRToRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv4CIDRToRange(NULL, NULL, NULL);) 2025.04.02 01:49:54.424099 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv4CIDRToRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:54.483423 [ 7799 ] {3dc880ca-9a96-4348-8668-acde6c50abae} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv4NumToString(NULL, NULL, NULL);) 2025.04.02 01:49:54.556372 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:54.593687 [ 7799 ] {491198a2-9dfb-496a-a7d5-f55bc2c823e3} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToStringClassC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv4NumToStringClassC(NULL, NULL, NULL);) 2025.04.02 01:49:54.609322 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToStringClassC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:54.657986 [ 7799 ] {188f7a9e-8aeb-463c-8748-1d8b4bba3dd3} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv4StringToNum(NULL, NULL, NULL);) 2025.04.02 01:49:54.671485 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:54.716394 [ 7799 ] {20f8d2a8-00e2-48b5-9f9f-d5b46d2fdc22} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv4StringToNumOrDefault(NULL, NULL, NULL);) 2025.04.02 01:49:54.725642 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:54.752868 [ 7799 ] {26b1ff87-7e7a-44df-b536-4ef1eb05bd98} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv4StringToNumOrNull(NULL, NULL, NULL);) 2025.04.02 01:49:54.772010 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:54.837660 [ 7799 ] {37b5e7c8-d6d6-481a-a096-e94c2ee10805} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 3, should be 1: In scope SELECT IPv4ToIPv6(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv4ToIPv6(NULL, NULL, NULL);) 2025.04.02 01:49:54.860998 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 3, should be 1: In scope SELECT IPv4ToIPv6(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:54.903947 [ 7799 ] {98f6e62b-9e24-497d-8c15-f34ccc02cf9e} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv6CIDRToRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv6CIDRToRange(NULL, NULL, NULL);) 2025.04.02 01:49:54.928281 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv6CIDRToRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:54.959012 [ 7799 ] {86105b69-5aff-46d0-95df-fbd9c69a482a} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv6NumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv6NumToString(NULL, NULL, NULL);) 2025.04.02 01:49:54.972753 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv6NumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:55.005717 [ 7799 ] {13f07a33-3554-4c99-9bdf-b9bec5ae6244} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv6StringToNum(NULL, NULL, NULL);) 2025.04.02 01:49:55.034709 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:55.072053 [ 7799 ] {10689176-3f3a-4948-943b-205923ec378b} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv6StringToNumOrDefault(NULL, NULL, NULL);) 2025.04.02 01:49:55.092009 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:55.195945 [ 7799 ] {c699ddd6-0081-4dda-ab3a-379c230ef636} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT IPv6StringToNumOrNull(NULL, NULL, NULL);) 2025.04.02 01:49:55.235128 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:55.285425 [ 7799 ] {29a37112-b812-45fe-85a2-c58fed827f8b} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 3, should be 1: In scope SELECT JSONAllPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSONAllPaths(NULL, NULL, NULL);) 2025.04.02 01:49:55.316887 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 3, should be 1: In scope SELECT JSONAllPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:55.366841 [ 7799 ] {3d1e6871-4476-4d43-b29e-eb77e541d290} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONAllPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSONAllPathsWithTypes(NULL, NULL, NULL);) 2025.04.02 01:49:55.400965 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONAllPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:55.431297 [ 7799 ] {5beceeac-71fe-4a66-8ee7-9de5d3dcc3dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSONArrayLength(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSONArrayLength(NULL, NULL, NULL);) 2025.04.02 01:49:55.442070 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSONArrayLength(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:55.485644 [ 7799 ] {a49a32fd-8ce1-4234-9f8d-e05abbdb0c07} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSONDynamicPaths(NULL, NULL, NULL);) 2025.04.02 01:49:55.496622 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:55.498000 [ 13512 ] {4541ce6d-1a29-4c68-b3c5-e1b820424525} executeQuery: Code: 252. DB::Exception: Too many parts (1 with average size of 171.00 B) in table 'test_rm6p1f93.table_for_alter (15fe5956-0ed9-43b1-a239-5eb8c86ae71e)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50968) (comment: 02280_add_query_level_settings.sql) (in query: INSERT INTO table_for_alter VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x000000003e0283b7 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4864: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000003df0cf49 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:76: DB::MergeTreeSink::onStart() @ 0x000000003eb86bdb 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x00000000400e12cc 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000400e0ff6 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x00000000400dfac2 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:103: DB::PushingPipelineExecutor::start() @ 0x000000003f76de83 13. ./build_docker/./src/Server/TCPHandler.cpp:1105: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003f44cc24 14. ./build_docker/./src/Server/TCPHandler.cpp:665: DB::TCPHandler::runImpl() @ 0x000000003f42c409 15. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 21. ? @ 0x00007f583d9b1ac3 22. ? @ 0x00007f583da43850 2025.04.02 01:49:55.502438 [ 13512 ] {} TCPHandler: Code: 252. DB::Exception: Too many parts (1 with average size of 171.00 B) in table 'test_rm6p1f93.table_for_alter (15fe5956-0ed9-43b1-a239-5eb8c86ae71e)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x000000003e0283b7 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4864: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000003df0cf49 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:76: DB::MergeTreeSink::onStart() @ 0x000000003eb86bdb 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x00000000400e12cc 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000400e0ff6 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x00000000400dfac2 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:103: DB::PushingPipelineExecutor::start() @ 0x000000003f76de83 13. ./build_docker/./src/Server/TCPHandler.cpp:1105: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003f44cc24 14. ./build_docker/./src/Server/TCPHandler.cpp:665: DB::TCPHandler::runImpl() @ 0x000000003f42c409 15. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 21. ? @ 0x00007f583d9b1ac3 22. ? @ 0x00007f583da43850 2025.04.02 01:49:55.544001 [ 7799 ] {c54a0378-1de8-4997-acc5-23dc118c1f95} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSONDynamicPathsWithTypes(NULL, NULL, NULL);) 2025.04.02 01:49:55.552336 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:55.599567 [ 7799 ] {6e72c150-2dbf-4a3f-b182-918bef7624f3} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: NULL: In scope SELECT JSONExtract(NULL, NULL, NULL). (ILLEGAL_COLUMN) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSONExtract(NULL, NULL, NULL);) 2025.04.02 01:49:55.623749 [ 7799 ] {} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: NULL: In scope SELECT JSONExtract(NULL, NULL, NULL). (ILLEGAL_COLUMN) 2025.04.02 01:49:55.752210 [ 13512 ] {338b7bb1-1ca2-4901-847d-f49a20636486} executeQuery: Code: 252. DB::Exception: Too many parts (2 with average size of 171.00 B) in table 'test_rm6p1f93.table_for_alter (15fe5956-0ed9-43b1-a239-5eb8c86ae71e)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50968) (comment: 02280_add_query_level_settings.sql) (in query: INSERT INTO table_for_alter VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x000000003e0283b7 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4864: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000003df0cf49 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:76: DB::MergeTreeSink::onStart() @ 0x000000003eb86bdb 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x00000000400e12cc 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000400e0ff6 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x00000000400dfac2 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:103: DB::PushingPipelineExecutor::start() @ 0x000000003f76de83 13. ./build_docker/./src/Server/TCPHandler.cpp:1105: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003f44cc24 14. ./build_docker/./src/Server/TCPHandler.cpp:665: DB::TCPHandler::runImpl() @ 0x000000003f42c409 15. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 21. ? @ 0x00007f583d9b1ac3 22. ? @ 0x00007f583da43850 2025.04.02 01:49:55.760035 [ 13512 ] {} TCPHandler: Code: 252. DB::Exception: Too many parts (2 with average size of 171.00 B) in table 'test_rm6p1f93.table_for_alter (15fe5956-0ed9-43b1-a239-5eb8c86ae71e)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x000000003e0283b7 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4864: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000003df0cf49 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:76: DB::MergeTreeSink::onStart() @ 0x000000003eb86bdb 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x00000000400e12cc 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000400e0ff6 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x00000000400dfac2 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:103: DB::PushingPipelineExecutor::start() @ 0x000000003f76de83 13. ./build_docker/./src/Server/TCPHandler.cpp:1105: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003f44cc24 14. ./build_docker/./src/Server/TCPHandler.cpp:665: DB::TCPHandler::runImpl() @ 0x000000003f42c409 15. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 21. ? @ 0x00007f583d9b1ac3 22. ? @ 0x00007f583da43850 2025.04.02 01:49:56.154824 [ 7799 ] {05e85f74-2ed6-4e29-8438-31ffca7abec1} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: NULL: In scope SELECT JSONExtractKeysAndValues(NULL, NULL, NULL). (ILLEGAL_COLUMN) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSONExtractKeysAndValues(NULL, NULL, NULL);) 2025.04.02 01:49:56.159996 [ 7799 ] {} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: NULL: In scope SELECT JSONExtractKeysAndValues(NULL, NULL, NULL). (ILLEGAL_COLUMN) 2025.04.02 01:49:57.169284 [ 7799 ] {cb5faad7-c3e5-4f5d-bc25-bd36d3a6f9f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSONSharedDataPaths(NULL, NULL, NULL);) 2025.04.02 01:49:57.179018 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:57.226519 [ 7799 ] {5e28f305-7a60-4d01-b0c3-c0afbd92970c} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSONSharedDataPathsWithTypes(NULL, NULL, NULL);) 2025.04.02 01:49:57.238209 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:57.412916 [ 7799 ] {cee56127-a99f-42f0-91fc-da745a128d9d} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSON_ARRAY_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT JSON_ARRAY_LENGTH(NULL, NULL, NULL);) 2025.04.02 01:49:57.438948 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSON_ARRAY_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:57.776985 [ 7799 ] {4e53c77e-dac9-43dc-9eb4-31c1668f8b2d} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT L1Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT L1Distance(NULL, NULL, NULL);) 2025.04.02 01:49:57.788490 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT L1Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:57.838536 [ 7799 ] {97f3fec2-386a-43e7-a1e1-45fad64084a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT L1Norm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT L1Norm(NULL, NULL, NULL);) 2025.04.02 01:49:57.854359 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT L1Norm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:57.887189 [ 7799 ] {882ab865-b962-42df-a84d-a34f46a85327} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT L1Normalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT L1Normalize(NULL, NULL, NULL);) 2025.04.02 01:49:57.911990 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT L1Normalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:57.938340 [ 7799 ] {94896b89-b45c-4364-a9bc-c9e04f1d6d86} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT L2Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT L2Distance(NULL, NULL, NULL);) 2025.04.02 01:49:57.957864 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT L2Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:57.993252 [ 7799 ] {5792704d-d83a-459b-8ca7-02373b0fd442} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT L2Norm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT L2Norm(NULL, NULL, NULL);) 2025.04.02 01:49:57.997562 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT L2Norm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:58.034166 [ 7799 ] {efe06f16-c0e5-4c0e-9c8c-70a23e9e6ace} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT L2Normalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT L2Normalize(NULL, NULL, NULL);) 2025.04.02 01:49:58.050898 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT L2Normalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:58.117146 [ 7799 ] {0f455b2b-f870-4491-a8fe-5a7de76fb986} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT L2SquaredDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT L2SquaredDistance(NULL, NULL, NULL);) 2025.04.02 01:49:58.132482 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT L2SquaredDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:58.175137 [ 7799 ] {3d28bfba-5210-4b4c-bdec-ce4608ad3d89} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT L2SquaredNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT L2SquaredNorm(NULL, NULL, NULL);) 2025.04.02 01:49:58.184108 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT L2SquaredNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:58.394581 [ 7799 ] {fb8db641-edcf-444b-b5f6-91c2ac5add60} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT LinfDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT LinfDistance(NULL, NULL, NULL);) 2025.04.02 01:49:58.406253 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT LinfDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:58.442663 [ 7799 ] {74390195-2566-4053-9a1b-ef522e6dab34} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT LinfNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT LinfNorm(NULL, NULL, NULL);) 2025.04.02 01:49:58.471382 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT LinfNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:58.488282 [ 7799 ] {ce3399f8-3e81-4582-b992-792ee030811f} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT LinfNormalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT LinfNormalize(NULL, NULL, NULL);) 2025.04.02 01:49:58.500117 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT LinfNormalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:58.624740 [ 7799 ] {1a19e97e-f80b-4f39-8612-718857e56653} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT LpNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT LpNorm(NULL, NULL, NULL);) 2025.04.02 01:49:58.648611 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT LpNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:58.674283 [ 7799 ] {57996d02-b38f-4f89-bfa1-c1d7e3ea4426} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT LpNormalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT LpNormalize(NULL, NULL, NULL);) 2025.04.02 01:49:58.702059 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT LpNormalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:58.724798 [ 7799 ] {68d077ab-c469-475a-8bad-707aa43b23ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 3, should be 1: In scope SELECT MACNumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT MACNumToString(NULL, NULL, NULL);) 2025.04.02 01:49:58.752259 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 3, should be 1: In scope SELECT MACNumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:58.788347 [ 7799 ] {1358493b-df85-4123-81f1-2794eac34ddf} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 3, should be 1: In scope SELECT MACStringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT MACStringToNum(NULL, NULL, NULL);) 2025.04.02 01:49:58.804809 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 3, should be 1: In scope SELECT MACStringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:58.843087 [ 7799 ] {28db531b-8412-48df-ab7f-1879e57bb5e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 3, should be 1: In scope SELECT MACStringToOUI(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT MACStringToOUI(NULL, NULL, NULL);) 2025.04.02 01:49:58.861501 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 3, should be 1: In scope SELECT MACStringToOUI(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:58.899965 [ 7799 ] {f57a0db9-474f-46b4-9a3a-c99f5e16ba11} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT MAP_FROM_ARRAYS(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT MAP_FROM_ARRAYS(NULL, NULL, NULL);) 2025.04.02 01:49:58.904747 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT MAP_FROM_ARRAYS(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:58.953311 [ 7799 ] {dc5a2700-004e-4dc5-9d2b-7940228b7912} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 3, should be 1: In scope SELECT MD4(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT MD4(NULL, NULL, NULL);) 2025.04.02 01:49:58.963418 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 3, should be 1: In scope SELECT MD4(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:58.996457 [ 7799 ] {e3912649-e6f3-4652-b417-c83171d5ee6b} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 3, should be 1: In scope SELECT MD5(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT MD5(NULL, NULL, NULL);) 2025.04.02 01:49:59.007235 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 3, should be 1: In scope SELECT MD5(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:59.265708 [ 7799 ] {d46e6df1-c1ff-4682-a526-7479b89a583a} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT OCTET_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT OCTET_LENGTH(NULL, NULL, NULL);) 2025.04.02 01:49:59.283103 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT OCTET_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:59.507900 [ 7799 ] {38c57f37-1698-44dc-872d-4a0462a1ba0c} executeQuery: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT REGEXP_MATCHES(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT REGEXP_MATCHES(NULL, NULL, NULL);) 2025.04.02 01:49:59.524949 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT REGEXP_MATCHES(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:59.648012 [ 7799 ] {a5d71e01-6fe1-428e-b9a7-c992793d964c} executeQuery: Code: 42. DB::Exception: Number of arguments for function RIPEMD160 doesn't match: passed 3, should be 1: In scope SELECT RIPEMD160(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT RIPEMD160(NULL, NULL, NULL);) 2025.04.02 01:49:59.695487 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function RIPEMD160 doesn't match: passed 3, should be 1: In scope SELECT RIPEMD160(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:59.713650 [ 7799 ] {a08d3ce0-70dc-4847-bd30-003ea47409c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT SCHEMA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT SCHEMA(NULL, NULL, NULL);) 2025.04.02 01:49:59.748850 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT SCHEMA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:59.922167 [ 7799 ] {59f07712-81aa-4509-9527-069a0f511ae5} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 3, should be 1: In scope SELECT SHA1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT SHA1(NULL, NULL, NULL);) 2025.04.02 01:49:59.959700 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 3, should be 1: In scope SELECT SHA1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:49:59.990345 [ 7799 ] {ef799800-94ff-44ff-af4e-d3b5c34638b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 3, should be 1: In scope SELECT SHA224(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT SHA224(NULL, NULL, NULL);) 2025.04.02 01:50:00.010783 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 3, should be 1: In scope SELECT SHA224(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:00.063684 [ 7799 ] {66ce826c-f983-48a9-bb74-5eb238c242bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 3, should be 1: In scope SELECT SHA256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT SHA256(NULL, NULL, NULL);) 2025.04.02 01:50:00.071599 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 3, should be 1: In scope SELECT SHA256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:00.120637 [ 7799 ] {8dde74a6-5548-4cf0-9f14-37b5cd54c258} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 3, should be 1: In scope SELECT SHA384(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT SHA384(NULL, NULL, NULL);) 2025.04.02 01:50:00.129726 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 3, should be 1: In scope SELECT SHA384(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:00.169031 [ 7799 ] {11ff5eab-2d38-44d7-a81b-6ca77c878b47} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 3, should be 1: In scope SELECT SHA512(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT SHA512(NULL, NULL, NULL);) 2025.04.02 01:50:00.186773 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 3, should be 1: In scope SELECT SHA512(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:00.248224 [ 7799 ] {a69e4b38-cc56-41ec-ab06-58ee6ebc5e7c} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 3, should be 1: In scope SELECT SHA512_256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT SHA512_256(NULL, NULL, NULL);) 2025.04.02 01:50:00.268917 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 3, should be 1: In scope SELECT SHA512_256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:00.529440 [ 14206 ] {31ef7f26-4045-4a0e-8cad-d457535ba655} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP key key1 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:51052) (comment: 01416_clear_column_pk.sql) (in query: ALTER TABLE table_with_pk_clear CLEAR COLUMN key1 IN PARTITION tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3678: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003deb3c99 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:218: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775be7b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:50:00.533704 [ 14206 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP key key1 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3678: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003deb3c99 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:218: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775be7b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:50:00.731646 [ 14206 ] {e8cc86f7-8ea6-4dea-bde6-458698534daa} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP key key2 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:51052) (comment: 01416_clear_column_pk.sql) (in query: ALTER TABLE table_with_pk_clear CLEAR COLUMN key2 IN PARTITION tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3678: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003deb3c99 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:218: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775be7b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:50:00.755599 [ 14206 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP key key2 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3678: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003deb3c99 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:218: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775be7b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 16. ? @ 0x00007f583d9b1ac3 17. ? @ 0x00007f583da43850 2025.04.02 01:50:00.874439 [ 7799 ] {3f93265a-a7cd-44eb-9d0c-250b5ebcc2da} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT TO_BASE64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT TO_BASE64(NULL, NULL, NULL);) 2025.04.02 01:50:00.884203 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT TO_BASE64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:01.105810 [ 7799 ] {949ac23b-f6b2-4f74-99d5-9a2956e87b4c} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT URLHierarchy(NULL, NULL, NULL);) 2025.04.02 01:50:01.110667 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:01.138298 [ 7799 ] {496855f0-e67f-4458-8e16-cf0c491fb907} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLPathHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT URLPathHierarchy(NULL, NULL, NULL);) 2025.04.02 01:50:01.142627 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLPathHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:01.170775 [ 7799 ] {7d12e08e-ad7f-4ed5-b0cd-411fb8d5853c} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT UTCTimestamp(NULL, NULL, NULL);) 2025.04.02 01:50:01.175444 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:01.205590 [ 7799 ] {17eb1ec5-ca9f-4609-a653-8b6ef0445e3b} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTC_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT UTC_timestamp(NULL, NULL, NULL);) 2025.04.02 01:50:01.209863 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTC_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:01.781507 [ 7799 ] {350b0776-626c-4b6c-b4ae-2e2a078a7714} executeQuery: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 3, should be 2: In scope SELECT _CAST(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT _CAST(NULL, NULL, NULL);) 2025.04.02 01:50:01.786789 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 3, should be 2: In scope SELECT _CAST(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:01.812657 [ 7799 ] {f00bbb65-766b-44e0-a0c4-1cdfd3faeee5} executeQuery: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 3, should be 2: In scope SELECT __actionName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT __actionName(NULL, NULL, NULL);) 2025.04.02 01:50:01.817259 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 3, should be 2: In scope SELECT __actionName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:01.843584 [ 7799 ] {8d3ebb79-bf45-47f8-a1e3-9f052df460b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskAnd doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT __bitBoolMaskAnd(NULL, NULL, NULL);) 2025.04.02 01:50:01.848930 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskAnd doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:01.877134 [ 7799 ] {392f309e-7285-4f6e-9bdb-b7a58c8e9428} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskOr doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT __bitBoolMaskOr(NULL, NULL, NULL);) 2025.04.02 01:50:01.881460 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskOr doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:01.909845 [ 7799 ] {84b88f98-ac4d-44e5-b256-d71bc5487ab8} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 3, should be 1: In scope SELECT __bitSwapLastTwo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT __bitSwapLastTwo(NULL, NULL, NULL);) 2025.04.02 01:50:01.914599 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 3, should be 1: In scope SELECT __bitSwapLastTwo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:01.941102 [ 7799 ] {28b07002-be64-443c-bb7d-ba57c2fdad0b} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 3, should be 1: In scope SELECT __bitWrapperFunc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT __bitWrapperFunc(NULL, NULL, NULL);) 2025.04.02 01:50:01.945545 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 3, should be 1: In scope SELECT __bitWrapperFunc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:01.974106 [ 7799 ] {cb1993d6-d053-453b-aa8b-e5fc63068a9b} executeQuery: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 3, should be 1: In scope SELECT __getScalar(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT __getScalar(NULL, NULL, NULL);) 2025.04.02 01:50:01.978456 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 3, should be 1: In scope SELECT __getScalar(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:02.006431 [ 7799 ] {4decdcd7-0b25-476c-9e97-10458fc82e04} executeQuery: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 3, should be 1: In scope SELECT __scalarSubqueryResult(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT __scalarSubqueryResult(NULL, NULL, NULL);) 2025.04.02 01:50:02.010802 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 3, should be 1: In scope SELECT __scalarSubqueryResult(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:02.036817 [ 7799 ] {e411ce37-2b89-4fe6-8489-e5b91a1e1341} executeQuery: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 3, should be 1: In scope SELECT abs(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT abs(NULL, NULL, NULL);) 2025.04.02 01:50:02.041106 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 3, should be 1: In scope SELECT abs(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:02.071332 [ 7799 ] {9daa6b9e-1a81-4a3c-b648-13edfda26dc9} executeQuery: Code: 42. DB::Exception: Number of arguments for function accurateCast doesn't match: passed 3, should be 2: In scope SELECT accurateCast(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT accurateCast(NULL, NULL, NULL);) 2025.04.02 01:50:02.076819 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function accurateCast doesn't match: passed 3, should be 2: In scope SELECT accurateCast(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:02.110878 [ 7799 ] {4f3e3129-5135-449c-9c73-e9b66614df07} executeQuery: Code: 43. DB::Exception: Second argument to accurateCastOrDefault must be a constant string describing type. Actual Nullable(Nothing): In scope SELECT accurateCastOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT accurateCastOrDefault(NULL, NULL, NULL);) 2025.04.02 01:50:02.116456 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: Second argument to accurateCastOrDefault must be a constant string describing type. Actual Nullable(Nothing): In scope SELECT accurateCastOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:02.149058 [ 7799 ] {83db032a-313e-4575-8d88-1a49239aaa77} executeQuery: Code: 42. DB::Exception: Number of arguments for function accurateCastOrNull doesn't match: passed 3, should be 2: In scope SELECT accurateCastOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT accurateCastOrNull(NULL, NULL, NULL);) 2025.04.02 01:50:02.154299 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function accurateCastOrNull doesn't match: passed 3, should be 2: In scope SELECT accurateCastOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:02.184866 [ 7799 ] {a530a83f-cb16-4d8d-835c-8dc7494d1e9d} executeQuery: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 3, should be 1: In scope SELECT acos(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT acos(NULL, NULL, NULL);) 2025.04.02 01:50:02.189577 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 3, should be 1: In scope SELECT acos(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:02.217859 [ 7799 ] {26243efc-d462-4b62-ab0a-ee2e2a7fca64} executeQuery: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 3, should be 1: In scope SELECT acosh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT acosh(NULL, NULL, NULL);) 2025.04.02 01:50:02.222071 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 3, should be 1: In scope SELECT acosh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:02.249291 [ 7799 ] {aec4c922-e42b-4652-b67b-f7ab025c41d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 3, should be 2: In scope SELECT addDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT addDate(NULL, NULL, NULL);) 2025.04.02 01:50:02.253790 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 3, should be 2: In scope SELECT addDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:02.383252 [ 7799 ] {de378127-3763-4470-b13d-be6b383db02b} executeQuery: Code: 42. DB::Exception: Number of arguments for function addInterval doesn't match: passed 3, should be 2: In scope SELECT addInterval(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT addInterval(NULL, NULL, NULL);) 2025.04.02 01:50:02.387943 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addInterval doesn't match: passed 3, should be 2: In scope SELECT addInterval(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:02.746414 [ 7799 ] {e81046bc-2d23-4dc2-86be-5618aa4b017e} executeQuery: Code: 42. DB::Exception: Number of arguments for function addTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT addTupleOfIntervals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT addTupleOfIntervals(NULL, NULL, NULL);) 2025.04.02 01:50:02.750545 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT addTupleOfIntervals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:02.881040 [ 7799 ] {8c5ffc27-06b7-42fb-a7b1-1e53cedfa3dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 3, should be 1: In scope SELECT addressToLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT addressToLine(NULL, NULL, NULL);) 2025.04.02 01:50:02.885727 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 3, should be 1: In scope SELECT addressToLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:02.911363 [ 7799 ] {d8a293a2-24ca-4a57-9d77-8efee323afb9} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 3, should be 1: In scope SELECT addressToLineWithInlines(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT addressToLineWithInlines(NULL, NULL, NULL);) 2025.04.02 01:50:02.915526 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 3, should be 1: In scope SELECT addressToLineWithInlines(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:02.943238 [ 7799 ] {b39d59ad-4bc1-4050-9d60-ce2db16edd0f} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 3, should be 1: In scope SELECT addressToSymbol(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT addressToSymbol(NULL, NULL, NULL);) 2025.04.02 01:50:02.947697 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 3, should be 1: In scope SELECT addressToSymbol(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:03.303643 [ 1424 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database nonexistent does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:529: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x0000000036890e14 5. ./build_docker/./src/Server/TCPHandler.cpp:337: DB::TCPHandler::runImpl() @ 0x000000003f428a1b 6. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:50:03.303972 [ 1424 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database nonexistent does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:529: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x0000000036890e14 5. ./build_docker/./src/Server/TCPHandler.cpp:337: DB::TCPHandler::runImpl() @ 0x000000003f428a1b 6. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 12. ? @ 0x00007f583d9b1ac3 13. ? @ 0x00007f583da43850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:50:03.519606 [ 7799 ] {1a7db42b-111b-4d54-9447-37e2aedbad84} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT anyLastRespectNulls(NULL, NULL, NULL);) 2025.04.02 01:50:03.523686 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:03.553265 [ 7799 ] {cdad5a46-8b1e-41fd-8744-a5a0845fe1aa} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT anyLast_respect_nulls(NULL, NULL, NULL);) 2025.04.02 01:50:03.557315 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:03.582115 [ 7799 ] {cc712194-2459-4ac3-9ba5-07287a8a0fc3} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT anyRespectNulls(NULL, NULL, NULL);) 2025.04.02 01:50:03.586574 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:03.614842 [ 7799 ] {5cba2363-fbea-4649-b190-ed6311237e7a} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT anyValueRespectNulls(NULL, NULL, NULL);) 2025.04.02 01:50:03.618848 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:03.643965 [ 7799 ] {78e2f736-0b56-4cf7-9a80-81be1447dfca} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT any_respect_nulls(NULL, NULL, NULL);) 2025.04.02 01:50:03.647833 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:03.723964 [ 7799 ] {12572fab-c1ae-406e-a50f-e668c954c0ab} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT any_value_respect_nulls(NULL, NULL, NULL);) 2025.04.02 01:50:03.728315 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:03.756027 [ 7799 ] {234bdcef-a55a-4600-bd8c-c287b1167a3a} executeQuery: Code: 42. DB::Exception: Number of arguments for function appendTrailingCharIfAbsent doesn't match: passed 3, should be 2: In scope SELECT appendTrailingCharIfAbsent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT appendTrailingCharIfAbsent(NULL, NULL, NULL);) 2025.04.02 01:50:03.759907 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function appendTrailingCharIfAbsent doesn't match: passed 3, should be 2: In scope SELECT appendTrailingCharIfAbsent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:04.142161 [ 7799 ] {19d46d35-ed22-43ac-9d42-0fc25de4c87f} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayAUCPR doesn't match: passed 3, should be 2: In scope SELECT arrayAUCPR(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayAUCPR(NULL, NULL, NULL);) 2025.04.02 01:50:04.146675 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayAUCPR doesn't match: passed 3, should be 2: In scope SELECT arrayAUCPR(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:04.548913 [ 7799 ] {36b5096d-55b2-42de-8ef1-7ee7db73c217} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 3, should be 1: In scope SELECT arrayDistinct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayDistinct(NULL, NULL, NULL);) 2025.04.02 01:50:04.553039 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 3, should be 1: In scope SELECT arrayDistinct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:04.581793 [ 7799 ] {9886995b-71e4-4b90-9dbb-36f62d29d303} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDotProduct doesn't match: passed 3, should be 2: In scope SELECT arrayDotProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayDotProduct(NULL, NULL, NULL);) 2025.04.02 01:50:04.585952 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDotProduct doesn't match: passed 3, should be 2: In scope SELECT arrayDotProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:04.614954 [ 7799 ] {6817338d-3568-4bc4-ac37-6bba98914c06} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayElement doesn't match: passed 3, should be 2: In scope SELECT arrayElement(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayElement(NULL, NULL, NULL);) 2025.04.02 01:50:04.619274 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayElement doesn't match: passed 3, should be 2: In scope SELECT arrayElement(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:04.647982 [ 7799 ] {08a0f842-8db0-48b4-8d73-f43844d261f5} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayElementOrNull doesn't match: passed 3, should be 2: In scope SELECT arrayElementOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayElementOrNull(NULL, NULL, NULL);) 2025.04.02 01:50:04.652177 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayElementOrNull doesn't match: passed 3, should be 2: In scope SELECT arrayElementOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:04.680415 [ 7799 ] {5198d5b8-86a9-496e-99d8-bb542b895ba3} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 3, should be 1: In scope SELECT arrayEnumerate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayEnumerate(NULL, NULL, NULL);) 2025.04.02 01:50:04.684651 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 3, should be 1: In scope SELECT arrayEnumerate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:05.158578 [ 7799 ] {4d796968-a259-4e84-a2bc-d1a583a00eb2} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT arrayFlatten(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayFlatten(NULL, NULL, NULL);) 2025.04.02 01:50:05.163293 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT arrayFlatten(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:05.189153 [ 7799 ] {be261b32-16d3-411c-a1b8-dc56d90cfb46} executeQuery: Code: 43. DB::Exception: First argument for function arrayFold must be a function: In scope SELECT arrayFold(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayFold(NULL, NULL, NULL);) 2025.04.02 01:50:05.194258 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayFold must be a function: In scope SELECT arrayFold(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:05.261298 [ 7799 ] {7b16f799-42bd-4b1c-a5c9-64b46e03c7b3} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT arrayJaccardIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayJaccardIndex(NULL, NULL, NULL);) 2025.04.02 01:50:05.265632 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT arrayJaccardIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:05.291927 [ 7799 ] {78c8be1a-c988-4b3f-99cf-e41bac9f127a} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 3, should be 1: In scope SELECT arrayJoin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayJoin(NULL, NULL, NULL);) 2025.04.02 01:50:05.297070 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 3, should be 1: In scope SELECT arrayJoin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:05.608646 [ 7799 ] {3b06aff5-9976-461e-b68e-38e3befdc057} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayAUCPR doesn't match: passed 3, should be 2: In scope SELECT arrayPRAUC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayPRAUC(NULL, NULL, NULL);) 2025.04.02 01:50:05.613654 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayAUCPR doesn't match: passed 3, should be 2: In scope SELECT arrayPRAUC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:05.780550 [ 7799 ] {efccbb99-6cba-455f-8760-78db0c6e9eaf} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 3, should be 1: In scope SELECT arrayPopBack(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayPopBack(NULL, NULL, NULL);) 2025.04.02 01:50:05.785255 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 3, should be 1: In scope SELECT arrayPopBack(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:05.813072 [ 7799 ] {24cdc8ae-ce19-4f5d-9fa0-77d3fb3e1ee9} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 3, should be 1: In scope SELECT arrayPopFront(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayPopFront(NULL, NULL, NULL);) 2025.04.02 01:50:05.817925 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 3, should be 1: In scope SELECT arrayPopFront(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:05.888862 [ 7799 ] {757e270a-837d-46e9-8e39-196c57b44520} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPushBack doesn't match: passed 3, should be 2: In scope SELECT arrayPushBack(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayPushBack(NULL, NULL, NULL);) 2025.04.02 01:50:05.893536 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPushBack doesn't match: passed 3, should be 2: In scope SELECT arrayPushBack(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:05.920664 [ 7799 ] {cb3297f8-9b28-4d6b-8c4b-ad789eaf06f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPushFront doesn't match: passed 3, should be 2: In scope SELECT arrayPushFront(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayPushFront(NULL, NULL, NULL);) 2025.04.02 01:50:05.925178 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPushFront doesn't match: passed 3, should be 2: In scope SELECT arrayPushFront(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:05.997790 [ 7799 ] {30dc8d39-c994-45b2-916d-567fe824f80d} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRandomSample doesn't match: passed 3, should be 2: In scope SELECT arrayRandomSample(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayRandomSample(NULL, NULL, NULL);) 2025.04.02 01:50:06.002354 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRandomSample doesn't match: passed 3, should be 2: In scope SELECT arrayRandomSample(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:06.028146 [ 7799 ] {cc1b8120-540c-4380-9291-16511b678f4a} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayReduce(NULL, NULL, NULL);) 2025.04.02 01:50:06.032684 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:06.158339 [ 7799 ] {3bf6e4ad-9233-47b6-a05a-150299a53cf7} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 3, should be 1: In scope SELECT arrayReverse(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayReverse(NULL, NULL, NULL);) 2025.04.02 01:50:06.163693 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 3, should be 1: In scope SELECT arrayReverse(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:06.338688 [ 7799 ] {cfa14f1d-2ff2-4636-a97b-bc6597c9dc22} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRotateLeft doesn't match: passed 3, should be 2: In scope SELECT arrayRotateLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayRotateLeft(NULL, NULL, NULL);) 2025.04.02 01:50:06.342901 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRotateLeft doesn't match: passed 3, should be 2: In scope SELECT arrayRotateLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:06.370694 [ 7799 ] {5a4e9d32-2795-4ed7-a0da-fceab7a7f48e} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRotateRight doesn't match: passed 3, should be 2: In scope SELECT arrayRotateRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayRotateRight(NULL, NULL, NULL);) 2025.04.02 01:50:06.375031 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRotateRight doesn't match: passed 3, should be 2: In scope SELECT arrayRotateRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:06.487448 [ 7799 ] {1b5f1c70-ebf0-4e90-8bc9-a4152c946730} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 3, should be 2: In scope SELECT arrayShingles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayShingles(NULL, NULL, NULL);) 2025.04.02 01:50:06.491691 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 3, should be 2: In scope SELECT arrayShingles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:06.855675 [ 7799 ] {d9797c24-8ecb-475d-b705-c7229e7dae29} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayWithConstant doesn't match: passed 3, should be 2: In scope SELECT arrayWithConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT arrayWithConstant(NULL, NULL, NULL);) 2025.04.02 01:50:06.860675 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayWithConstant doesn't match: passed 3, should be 2: In scope SELECT arrayWithConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:07.036804 [ 7799 ] {a134ecd4-326e-47c5-ac19-c9f0386ef3fe} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function with Array suffix. Must be array. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT array_concat_agg(NULL, NULL, NULL);) 2025.04.02 01:50:07.041172 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function with Array suffix. Must be array. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:07.069098 [ 7799 ] {fdfa1f8d-22f8-4225-8899-1c7571a82186} executeQuery: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 3, should be 1: In scope SELECT ascii(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ascii(NULL, NULL, NULL);) 2025.04.02 01:50:07.073228 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 3, should be 1: In scope SELECT ascii(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:07.101101 [ 7799 ] {7bdf7acf-d339-4d56-a2ea-0f19f3143a93} executeQuery: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 3, should be 1: In scope SELECT asin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT asin(NULL, NULL, NULL);) 2025.04.02 01:50:07.105300 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 3, should be 1: In scope SELECT asin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:07.135085 [ 7799 ] {62f97997-7365-40db-ac05-5ee4e21481f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 3, should be 1: In scope SELECT asinh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT asinh(NULL, NULL, NULL);) 2025.04.02 01:50:07.139493 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 3, should be 1: In scope SELECT asinh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:07.168586 [ 7799 ] {f3d93da3-f468-43de-a193-deee606adf69} executeQuery: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 3, should be 1: In scope SELECT assumeNotNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT assumeNotNull(NULL, NULL, NULL);) 2025.04.02 01:50:07.173020 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 3, should be 1: In scope SELECT assumeNotNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:07.198313 [ 7799 ] {87a4d67b-08da-4a58-9097-4962a198c906} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 3, should be 1: In scope SELECT atan(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT atan(NULL, NULL, NULL);) 2025.04.02 01:50:07.202647 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 3, should be 1: In scope SELECT atan(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:07.226764 [ 7799 ] {82a6d505-bb4b-454b-b169-a33e1b8409b3} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan2 doesn't match: passed 3, should be 2: In scope SELECT atan2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT atan2(NULL, NULL, NULL);) 2025.04.02 01:50:07.231491 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan2 doesn't match: passed 3, should be 2: In scope SELECT atan2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:07.257059 [ 7799 ] {46ef7a48-daaa-46a6-951d-865127e83c21} executeQuery: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 3, should be 1: In scope SELECT atanh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT atanh(NULL, NULL, NULL);) 2025.04.02 01:50:07.261111 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 3, should be 1: In scope SELECT atanh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:07.442011 [ 7799 ] {86b94623-71b0-4650-9f54-cd51b7b0cce4} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 3, should be 1: In scope SELECT base58Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT base58Decode(NULL, NULL, NULL);) 2025.04.02 01:50:07.446368 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 3, should be 1: In scope SELECT base58Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:07.471250 [ 7799 ] {0a06f7e6-92e3-4b86-bbde-1d4799061028} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 3, should be 1: In scope SELECT base58Encode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT base58Encode(NULL, NULL, NULL);) 2025.04.02 01:50:07.475597 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 3, should be 1: In scope SELECT base58Encode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:07.500560 [ 7799 ] {876ad0dc-b1e0-45b2-90d3-62b555a7c94e} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT base64Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT base64Decode(NULL, NULL, NULL);) 2025.04.02 01:50:07.504778 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT base64Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:07.529195 [ 7799 ] {2497d45a-9409-4235-9c6e-cc98619e8209} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT base64Encode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT base64Encode(NULL, NULL, NULL);) 2025.04.02 01:50:07.533237 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT base64Encode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:07.557651 [ 7799 ] {2220681c-d620-4c05-bd9e-38c6ac6c098d} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 3, should be 1: In scope SELECT base64URLDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT base64URLDecode(NULL, NULL, NULL);) 2025.04.02 01:50:07.561714 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 3, should be 1: In scope SELECT base64URLDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:07.585845 [ 7799 ] {a6e1df30-3337-41b3-b2ee-b06c5645234a} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 3, should be 1: In scope SELECT base64URLEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT base64URLEncode(NULL, NULL, NULL);) 2025.04.02 01:50:07.590173 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 3, should be 1: In scope SELECT base64URLEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:07.614891 [ 7799 ] {974e4883-dc0b-4bdf-b621-3a876757b5fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 3, should be 1: In scope SELECT basename(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT basename(NULL, NULL, NULL);) 2025.04.02 01:50:07.618906 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 3, should be 1: In scope SELECT basename(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:07.643226 [ 7799 ] {9fbf9a97-0195-440f-8cf7-b8f1c8781267} executeQuery: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 3, should be 1: In scope SELECT bin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bin(NULL, NULL, NULL);) 2025.04.02 01:50:07.647301 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 3, should be 1: In scope SELECT bin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:07.672673 [ 7799 ] {016496be-481f-42a2-9a62-550085e2521e} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitAnd doesn't match: passed 3, should be 2: In scope SELECT bitAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitAnd(NULL, NULL, NULL);) 2025.04.02 01:50:07.676856 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitAnd doesn't match: passed 3, should be 2: In scope SELECT bitAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:07.702881 [ 7799 ] {53f6ec7c-1b95-4886-83a6-d1165596c090} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 3, should be 1: In scope SELECT bitCount(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitCount(NULL, NULL, NULL);) 2025.04.02 01:50:07.706990 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 3, should be 1: In scope SELECT bitCount(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:07.734568 [ 7799 ] {efb171c2-60f5-4fd6-9e96-447eecd10856} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitHammingDistance doesn't match: passed 3, should be 2: In scope SELECT bitHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitHammingDistance(NULL, NULL, NULL);) 2025.04.02 01:50:07.739096 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitHammingDistance doesn't match: passed 3, should be 2: In scope SELECT bitHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:07.765102 [ 7799 ] {16d451c7-5e20-49ec-9814-474357643435} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 3, should be 1: In scope SELECT bitNot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitNot(NULL, NULL, NULL);) 2025.04.02 01:50:07.769634 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 3, should be 1: In scope SELECT bitNot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:07.796629 [ 7799 ] {8c2ad4ae-bf14-42d9-b4ef-b898bc5f015b} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitOr doesn't match: passed 3, should be 2: In scope SELECT bitOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitOr(NULL, NULL, NULL);) 2025.04.02 01:50:07.800830 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitOr doesn't match: passed 3, should be 2: In scope SELECT bitOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:07.826875 [ 7799 ] {3fa5b580-2be2-4424-b3fb-a767c90e2633} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 3, should be 1: In scope SELECT bitPositionsToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitPositionsToArray(NULL, NULL, NULL);) 2025.04.02 01:50:07.831376 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 3, should be 1: In scope SELECT bitPositionsToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:07.860214 [ 7799 ] {33102e14-4027-4db4-949f-8e8dcd365c48} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitRotateLeft doesn't match: passed 3, should be 2: In scope SELECT bitRotateLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitRotateLeft(NULL, NULL, NULL);) 2025.04.02 01:50:07.864523 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitRotateLeft doesn't match: passed 3, should be 2: In scope SELECT bitRotateLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:07.892356 [ 7799 ] {0cac1bce-0225-48c0-be6c-ee2f2d856298} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitRotateRight doesn't match: passed 3, should be 2: In scope SELECT bitRotateRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitRotateRight(NULL, NULL, NULL);) 2025.04.02 01:50:07.896721 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitRotateRight doesn't match: passed 3, should be 2: In scope SELECT bitRotateRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:07.924307 [ 7799 ] {2ac81381-9909-4e8e-96bc-658719942571} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitShiftLeft doesn't match: passed 3, should be 2: In scope SELECT bitShiftLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitShiftLeft(NULL, NULL, NULL);) 2025.04.02 01:50:07.928622 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitShiftLeft doesn't match: passed 3, should be 2: In scope SELECT bitShiftLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:07.953789 [ 7799 ] {165f749e-8a66-4ffa-9fc0-66816503a582} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitShiftRight doesn't match: passed 3, should be 2: In scope SELECT bitShiftRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitShiftRight(NULL, NULL, NULL);) 2025.04.02 01:50:07.958359 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitShiftRight doesn't match: passed 3, should be 2: In scope SELECT bitShiftRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:08.036600 [ 7799 ] {97e412ca-1e0d-4a47-a653-62afcb2d5fd3} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitTest doesn't match: passed 3, should be 2: In scope SELECT bitTest(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitTest(NULL, NULL, NULL);) 2025.04.02 01:50:08.041600 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitTest doesn't match: passed 3, should be 2: In scope SELECT bitTest(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:08.165242 [ 7799 ] {631688e5-de66-4577-a004-65da79b395b6} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitXor doesn't match: passed 3, should be 2: In scope SELECT bitXor(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitXor(NULL, NULL, NULL);) 2025.04.02 01:50:08.169684 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitXor doesn't match: passed 3, should be 2: In scope SELECT bitXor(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:08.196616 [ 7799 ] {4991a59d-44b3-4380-b180-940a76e2ba44} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAnd doesn't match: passed 3, should be 2: In scope SELECT bitmapAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapAnd(NULL, NULL, NULL);) 2025.04.02 01:50:08.200649 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAnd doesn't match: passed 3, should be 2: In scope SELECT bitmapAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:08.227740 [ 7799 ] {1ed13d02-25b4-4bee-9eaf-dc7b607edeae} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapAndCardinality(NULL, NULL, NULL);) 2025.04.02 01:50:08.232123 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:08.259280 [ 7799 ] {699ca4f9-6288-408a-bd31-9a4ed7d9d5c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndnot doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapAndnot(NULL, NULL, NULL);) 2025.04.02 01:50:08.263657 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndnot doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:08.291843 [ 7799 ] {29b64146-b867-4450-8219-25e742464a06} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndnotCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnotCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapAndnotCardinality(NULL, NULL, NULL);) 2025.04.02 01:50:08.296113 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndnotCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnotCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:08.320814 [ 7799 ] {0dfc054c-c944-4544-a46a-ffc293d56025} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 3, should be 1: In scope SELECT bitmapBuild(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapBuild(NULL, NULL, NULL);) 2025.04.02 01:50:08.325009 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 3, should be 1: In scope SELECT bitmapBuild(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:08.355814 [ 7799 ] {6c3adeb6-8e8f-4038-80f2-0cdceb16828b} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 3, should be 1: In scope SELECT bitmapCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapCardinality(NULL, NULL, NULL);) 2025.04.02 01:50:08.360257 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 3, should be 1: In scope SELECT bitmapCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:08.392462 [ 7799 ] {6551a0f7-6a3f-4b7f-a2f4-6b4cdd94aa35} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapContains doesn't match: passed 3, should be 2: In scope SELECT bitmapContains(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapContains(NULL, NULL, NULL);) 2025.04.02 01:50:08.398006 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapContains doesn't match: passed 3, should be 2: In scope SELECT bitmapContains(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:08.426733 [ 7799 ] {73e02975-94e4-46b9-a8d6-1785f5f5ee22} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapHasAll doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapHasAll(NULL, NULL, NULL);) 2025.04.02 01:50:08.431640 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapHasAll doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:08.456457 [ 7799 ] {866d35f9-ec03-40ab-bbb7-03085c02d1dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapHasAny doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapHasAny(NULL, NULL, NULL);) 2025.04.02 01:50:08.460987 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapHasAny doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:08.487328 [ 7799 ] {b5c422dd-0457-4233-aa9f-2ff376213145} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 3, should be 1: In scope SELECT bitmapMax(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapMax(NULL, NULL, NULL);) 2025.04.02 01:50:08.491645 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 3, should be 1: In scope SELECT bitmapMax(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:08.517126 [ 7799 ] {2fe3d9e6-0a46-477d-8197-db66bf79c54a} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 3, should be 1: In scope SELECT bitmapMin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapMin(NULL, NULL, NULL);) 2025.04.02 01:50:08.521389 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 3, should be 1: In scope SELECT bitmapMin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:08.547672 [ 7799 ] {906b1acd-cc25-47e4-9651-cfed31c9d3e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapOr doesn't match: passed 3, should be 2: In scope SELECT bitmapOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapOr(NULL, NULL, NULL);) 2025.04.02 01:50:08.551948 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapOr doesn't match: passed 3, should be 2: In scope SELECT bitmapOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:08.576497 [ 7799 ] {d9685dc2-380f-42d7-b1b1-59d7781a3d86} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapOrCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapOrCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapOrCardinality(NULL, NULL, NULL);) 2025.04.02 01:50:08.580654 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapOrCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapOrCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:08.692041 [ 7799 ] {4daa1377-52fd-44e5-8aaf-4a0fabbd6d33} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 3, should be 1: In scope SELECT bitmapToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapToArray(NULL, NULL, NULL);) 2025.04.02 01:50:08.696258 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 3, should be 1: In scope SELECT bitmapToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:08.763519 [ 7799 ] {8567060b-7100-4562-9e9e-f9251b2e1338} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapXor doesn't match: passed 3, should be 2: In scope SELECT bitmapXor(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapXor(NULL, NULL, NULL);) 2025.04.02 01:50:08.767549 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapXor doesn't match: passed 3, should be 2: In scope SELECT bitmapXor(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:08.792738 [ 7799 ] {2736b835-9970-47fe-83d5-efd622c20664} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapXorCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapXorCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmapXorCardinality(NULL, NULL, NULL);) 2025.04.02 01:50:08.797041 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapXorCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapXorCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:08.825518 [ 7799 ] {718d0efa-0a51-4108-955a-175dec92eb80} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 3, should be 1: In scope SELECT bitmaskToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmaskToArray(NULL, NULL, NULL);) 2025.04.02 01:50:08.829897 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 3, should be 1: In scope SELECT bitmaskToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:08.856754 [ 7799 ] {54077491-4c00-48b6-8f4c-8b976c2cb4c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 3, should be 1: In scope SELECT bitmaskToList(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT bitmaskToList(NULL, NULL, NULL);) 2025.04.02 01:50:08.860909 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 3, should be 1: In scope SELECT bitmaskToList(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:08.888679 [ 7799 ] {873c8f70-fa87-4ded-887a-1cc4bc953b58} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 3, should be 0: In scope SELECT blockNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT blockNumber(NULL, NULL, NULL);) 2025.04.02 01:50:08.892866 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 3, should be 0: In scope SELECT blockNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:08.973140 [ 7799 ] {cdab2594-0430-4167-b07c-2e352d2f78a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 3, should be 0: In scope SELECT blockSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT blockSize(NULL, NULL, NULL);) 2025.04.02 01:50:08.977932 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 3, should be 0: In scope SELECT blockSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:09.067687 [ 7799 ] {779fd733-de19-4847-b7aa-b3ad2cf73581} executeQuery: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 3, should be 0: In scope SELECT buildId(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT buildId(NULL, NULL, NULL);) 2025.04.02 01:50:09.073091 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 3, should be 0: In scope SELECT buildId(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:09.104822 [ 7799 ] {7a9c0387-80b3-4575-bbf9-1d009bbe5191} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT byteHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT byteHammingDistance(NULL, NULL, NULL);) 2025.04.02 01:50:09.110376 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT byteHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:09.243803 [ 7799 ] {b53dae9c-c982-4e4e-84dc-1f095cdceb26} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 3, should be 1: In scope SELECT byteSwap(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT byteSwap(NULL, NULL, NULL);) 2025.04.02 01:50:09.249175 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 3, should be 1: In scope SELECT byteSwap(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:09.462971 [ 7799 ] {aad5cfad-78da-4745-847b-cfcddc53820e} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function catboostEvaluate, expected a string.: In scope SELECT catboostEvaluate(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT catboostEvaluate(NULL, NULL, NULL);) 2025.04.02 01:50:09.467131 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function catboostEvaluate, expected a string.: In scope SELECT catboostEvaluate(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:09.496648 [ 7799 ] {cd9f041a-5202-44b7-9789-84962304d100} executeQuery: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT categoricalInformationValue(NULL, NULL, NULL);) 2025.04.02 01:50:09.500758 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:09.526843 [ 7799 ] {b3144e84-8c84-464e-85fb-b93ce8f4c309} executeQuery: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 3, should be 1: In scope SELECT cbrt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cbrt(NULL, NULL, NULL);) 2025.04.02 01:50:09.530954 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 3, should be 1: In scope SELECT cbrt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:09.660131 [ 7799 ] {d559504e-a85f-475d-9aaa-3b5e35df2004} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeDay doesn't match: passed 3, should be 2: In scope SELECT changeDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT changeDay(NULL, NULL, NULL);) 2025.04.02 01:50:09.664921 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeDay doesn't match: passed 3, should be 2: In scope SELECT changeDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:09.694059 [ 7799 ] {11c51ea3-a68a-4513-b5cd-e762a5cbe24f} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeHour doesn't match: passed 3, should be 2: In scope SELECT changeHour(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT changeHour(NULL, NULL, NULL);) 2025.04.02 01:50:09.699296 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeHour doesn't match: passed 3, should be 2: In scope SELECT changeHour(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:09.729574 [ 7799 ] {94d88188-8895-4232-ad40-19e2d884cb9d} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeMinute doesn't match: passed 3, should be 2: In scope SELECT changeMinute(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT changeMinute(NULL, NULL, NULL);) 2025.04.02 01:50:09.735703 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeMinute doesn't match: passed 3, should be 2: In scope SELECT changeMinute(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:09.767001 [ 7799 ] {8d288ab0-4600-4cd3-b372-cd7b21eefe36} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeMonth doesn't match: passed 3, should be 2: In scope SELECT changeMonth(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT changeMonth(NULL, NULL, NULL);) 2025.04.02 01:50:09.772346 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeMonth doesn't match: passed 3, should be 2: In scope SELECT changeMonth(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:09.801729 [ 7799 ] {e2ba1fc2-1b47-453f-9a91-01dfa8968a05} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeSecond doesn't match: passed 3, should be 2: In scope SELECT changeSecond(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT changeSecond(NULL, NULL, NULL);) 2025.04.02 01:50:09.806477 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeSecond doesn't match: passed 3, should be 2: In scope SELECT changeSecond(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:09.837094 [ 7799 ] {68e47c42-d640-48a7-8733-de09ce9e7948} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 3, should be 2: In scope SELECT changeYear(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT changeYear(NULL, NULL, NULL);) 2025.04.02 01:50:09.842250 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 3, should be 2: In scope SELECT changeYear(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:10.157338 [ 14191 ] {99820a69-06dc-4f32-b5bc-0d5fae72f8d3} executeQuery: Code: 20. DB::Exception: Number of columns in section IN doesn't match. 1 at left, 2 at right.: while executing 'FUNCTION nullIn(str : 0, __set_1106107118064107275_13075651177415603779 :: 1) -> nullIn(__table1.str, __set_1106107118064107275_13075651177415603779) UInt8 : 2': While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:60512) (comment: 01681_bloom_filter_nullable_column.sql) (in query: SELECT * FROM bloom_filter_nullable_index WHERE str IN (SELECT '1048576', str FROM bloom_filter_nullable_index) SETTINGS transform_null_in = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&&) @ 0x0000000008b130ed 4. ./build_docker/./src/Interpreters/Set.cpp:571: DB::Set::execute(std::vector> const&, bool) const @ 0x0000000038a5afbf 5. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011fafc87 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x00000000369275c8 12. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1499: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x000000003e4a98b9 13. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1081: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000003e4a379f 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:980: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000003e49fb95 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read() @ 0x000000003e512177 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000408ec431 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:192: DB::MergeTreeSelectProcessor::read() @ 0x000000003e504057 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:225: DB::MergeTreeSource::tryGenerate() @ 0x00000000408f62b2 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003f6e8571 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003f7213f8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002097cef4 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002098fd26 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002098fadf 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 28. ? @ 0x00007f583d9b1ac3 29. ? @ 0x00007f583da43850 2025.04.02 01:50:10.164919 [ 14191 ] {} TCPHandler: Code: 20. DB::Exception: Number of columns in section IN doesn't match. 1 at left, 2 at right.: while executing 'FUNCTION nullIn(str : 0, __set_1106107118064107275_13075651177415603779 :: 1) -> nullIn(__table1.str, __set_1106107118064107275_13075651177415603779) UInt8 : 2': While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&&) @ 0x0000000008b130ed 4. ./build_docker/./src/Interpreters/Set.cpp:571: DB::Set::execute(std::vector> const&, bool) const @ 0x0000000038a5afbf 5. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011fafc87 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x00000000369275c8 12. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1499: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x000000003e4a98b9 13. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1081: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000003e4a379f 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:980: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000003e49fb95 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read() @ 0x000000003e512177 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000408ec431 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:192: DB::MergeTreeSelectProcessor::read() @ 0x000000003e504057 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:225: DB::MergeTreeSource::tryGenerate() @ 0x00000000408f62b2 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003f6e8571 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003f7213f8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002097cef4 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002098fd26 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002098fadf 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 28. ? @ 0x00007f583d9b1ac3 29. ? @ 0x00007f583da43850 2025.04.02 01:50:10.253096 [ 14191 ] {7f7ec4b1-4ca7-4779-a357-127edcf566ff} executeQuery: Code: 20. DB::Exception: Number of columns in section IN doesn't match. 1 at left, 2 at right.: while executing 'FUNCTION nullIn(str : 0, __set_1106107118064107275_13075651177415603779 :: 1) -> nullIn(__table1.str, __set_1106107118064107275_13075651177415603779) UInt8 : 2': While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:60512) (comment: 01681_bloom_filter_nullable_column.sql) (in query: SELECT * FROM bloom_filter_nullable_index WHERE str IN (SELECT '1048576', str FROM bloom_filter_nullable_index) SETTINGS transform_null_in = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&&) @ 0x0000000008b130ed 4. ./build_docker/./src/Interpreters/Set.cpp:571: DB::Set::execute(std::vector> const&, bool) const @ 0x0000000038a5afbf 5. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011fafc87 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x00000000369275c8 12. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1499: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x000000003e4a98b9 13. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1081: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000003e4a379f 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:980: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000003e49fb95 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read() @ 0x000000003e512177 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000408ec431 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:192: DB::MergeTreeSelectProcessor::read() @ 0x000000003e504057 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:225: DB::MergeTreeSource::tryGenerate() @ 0x00000000408f62b2 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003f6e8571 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003f7213f8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002097cef4 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002098fd26 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002098fadf 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 28. ? @ 0x00007f583d9b1ac3 29. ? @ 0x00007f583da43850 2025.04.02 01:50:10.258376 [ 14191 ] {} TCPHandler: Code: 20. DB::Exception: Number of columns in section IN doesn't match. 1 at left, 2 at right.: while executing 'FUNCTION nullIn(str : 0, __set_1106107118064107275_13075651177415603779 :: 1) -> nullIn(__table1.str, __set_1106107118064107275_13075651177415603779) UInt8 : 2': While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&&) @ 0x0000000008b130ed 4. ./build_docker/./src/Interpreters/Set.cpp:571: DB::Set::execute(std::vector> const&, bool) const @ 0x0000000038a5afbf 5. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011fafc87 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06efb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf55aa 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000003692246b 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x00000000369275c8 12. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1499: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x000000003e4a98b9 13. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1081: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000003e4a379f 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:980: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000003e49fb95 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read() @ 0x000000003e512177 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000408ec431 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:192: DB::MergeTreeSelectProcessor::read() @ 0x000000003e504057 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:225: DB::MergeTreeSource::tryGenerate() @ 0x00000000408f62b2 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003f6e8571 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003f7213f8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002097cef4 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002098fd26 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002098fadf 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 28. ? @ 0x00007f583d9b1ac3 29. ? @ 0x00007f583da43850 2025.04.02 01:50:10.284426 [ 7799 ] {bb898399-ea95-46e2-b3e7-1a0f36482b6c} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connectionId(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT connectionId(NULL, NULL, NULL);) 2025.04.02 01:50:10.288541 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connectionId(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:10.311518 [ 7799 ] {70a29367-6ac7-41d1-89c2-b6122d8e192a} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connection_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT connection_id(NULL, NULL, NULL);) 2025.04.02 01:50:10.315657 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connection_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:10.594334 [ 7799 ] {d4298c9a-8ce4-468f-92eb-51e449f2095a} executeQuery: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 3, should be 1: In scope SELECT cos(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cos(NULL, NULL, NULL);) 2025.04.02 01:50:10.598362 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 3, should be 1: In scope SELECT cos(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:10.625694 [ 7799 ] {e09a33ca-cecf-413c-a3c2-2ce9b4559e60} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 3, should be 1: In scope SELECT cosh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cosh(NULL, NULL, NULL);) 2025.04.02 01:50:10.629807 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 3, should be 1: In scope SELECT cosh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:10.657841 [ 7799 ] {4bc836f5-9a00-4775-815e-356818a95915} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosineDistance doesn't match: passed 3, should be 2: In scope SELECT cosineDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cosineDistance(NULL, NULL, NULL);) 2025.04.02 01:50:10.662143 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosineDistance doesn't match: passed 3, should be 2: In scope SELECT cosineDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:10.687672 [ 7799 ] {f6852eb8-dc56-4899-92e2-e23370655bdc} executeQuery: Code: 42. DB::Exception: Aggregate function count requires zero or one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT count(NULL, NULL, NULL);) 2025.04.02 01:50:10.692154 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function count requires zero or one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:10.718160 [ 7799 ] {65567a37-ce64-4350-b612-96e9aa7231d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 3, should be 1: In scope SELECT countDigits(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT countDigits(NULL, NULL, NULL);) 2025.04.02 01:50:10.722390 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 3, should be 1: In scope SELECT countDigits(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:10.747292 [ 7799 ] {122390c5-88f6-428c-9af7-0409dfbbaa56} executeQuery: Code: 42. DB::Exception: Number of arguments for function countEqual doesn't match: passed 3, should be 2: In scope SELECT countEqual(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT countEqual(NULL, NULL, NULL);) 2025.04.02 01:50:10.751583 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countEqual doesn't match: passed 3, should be 2: In scope SELECT countEqual(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:10.776015 [ 7799 ] {0af470f8-1ddf-4bb9-adf0-283bd7bc7768} executeQuery: Code: 42. DB::Exception: Number of arguments for function countMatches doesn't match: passed 3, should be 2: In scope SELECT countMatches(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT countMatches(NULL, NULL, NULL);) 2025.04.02 01:50:10.780167 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countMatches doesn't match: passed 3, should be 2: In scope SELECT countMatches(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:10.807019 [ 7799 ] {e3200e59-df99-4ab4-bf47-ab2b60306c3e} executeQuery: Code: 42. DB::Exception: Number of arguments for function countMatchesCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT countMatchesCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT countMatchesCaseInsensitive(NULL, NULL, NULL);) 2025.04.02 01:50:10.811445 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countMatchesCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT countMatchesCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:11.370388 [ 7799 ] {2d186cf6-599d-4fa5-a25d-9c0f46c777b9} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT curdate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT curdate(NULL, NULL, NULL);) 2025.04.02 01:50:11.374462 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT curdate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:11.399459 [ 7799 ] {b88f7bdb-f7db-4f67-b63e-acfecb916145} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT currentDatabase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT currentDatabase(NULL, NULL, NULL);) 2025.04.02 01:50:11.403890 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT currentDatabase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:11.429773 [ 7799 ] {de32b86a-703a-4a06-91d9-f742a2d54840} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 3, should be 0: In scope SELECT currentProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT currentProfiles(NULL, NULL, NULL);) 2025.04.02 01:50:11.433690 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 3, should be 0: In scope SELECT currentProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:11.459306 [ 7799 ] {f00a0462-52ce-4af9-b5df-4c8032e901d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 3, should be 0: In scope SELECT currentRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT currentRoles(NULL, NULL, NULL);) 2025.04.02 01:50:11.463450 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 3, should be 0: In scope SELECT currentRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:11.489712 [ 7799 ] {0a3a16ed-c4b4-4c46-8738-b61ba698addc} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT currentSchemas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT currentSchemas(NULL, NULL, NULL);) 2025.04.02 01:50:11.494367 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT currentSchemas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:11.520823 [ 7799 ] {39e90716-e40c-4d9e-9223-53cf5a298957} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT currentUser(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT currentUser(NULL, NULL, NULL);) 2025.04.02 01:50:11.525095 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT currentUser(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:11.551136 [ 7799 ] {48308b8a-81fd-47e3-9a1c-fafef1aa92e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT current_database(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT current_database(NULL, NULL, NULL);) 2025.04.02 01:50:11.555014 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT current_database(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:11.581305 [ 7799 ] {f70a60f3-fe55-4465-8b04-1366555a366f} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT current_date(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT current_date(NULL, NULL, NULL);) 2025.04.02 01:50:11.585346 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT current_date(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:11.614739 [ 7799 ] {1097ad3d-67ab-4966-acf1-4e337a5900c3} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT current_schemas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT current_schemas(NULL, NULL, NULL);) 2025.04.02 01:50:11.619274 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT current_schemas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:11.648594 [ 7799 ] {f6fdca3f-7568-4f85-b887-ee68c1c41287} executeQuery: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT current_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT current_timestamp(NULL, NULL, NULL);) 2025.04.02 01:50:11.653095 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT current_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:11.680861 [ 7799 ] {efc72e3e-c8ed-4c6e-a01e-2f19c3b78977} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT current_user(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT current_user(NULL, NULL, NULL);) 2025.04.02 01:50:11.684975 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT current_user(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:11.709922 [ 7799 ] {5130a7bd-25c4-4c06-a299-5c1616c7c1ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 3, should be 1: In scope SELECT cutFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutFragment(NULL, NULL, NULL);) 2025.04.02 01:50:11.713878 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 3, should be 1: In scope SELECT cutFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:11.784055 [ 7799 ] {8b7346a5-e9a7-438a-8f3c-d6160a8731e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 3, should be 1: In scope SELECT cutQueryString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutQueryString(NULL, NULL, NULL);) 2025.04.02 01:50:11.788075 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 3, should be 1: In scope SELECT cutQueryString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:11.812216 [ 7799 ] {d65bc603-9e70-4028-84bb-6397f15452e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT cutQueryStringAndFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutQueryStringAndFragment(NULL, NULL, NULL);) 2025.04.02 01:50:11.816353 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT cutQueryStringAndFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:11.841892 [ 7799 ] {387817f3-e247-4656-a6da-5a5cf2edc3b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutToFirstSignificantSubdomain(NULL, NULL, NULL);) 2025.04.02 01:50:11.845955 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:11.867065 [ 7799 ] {8aa34fbf-20d8-485f-9114-7698e0bff19e} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutToFirstSignificantSubdomainCustom(NULL, NULL, NULL);) 2025.04.02 01:50:11.871204 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:11.898534 [ 7799 ] {854d47dc-2774-4284-b2de-958cc8eeede5} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutToFirstSignificantSubdomainCustomRFC(NULL, NULL, NULL);) 2025.04.02 01:50:11.902947 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:11.929527 [ 7799 ] {09882640-a12d-4c82-a658-911abec76216} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWW doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutToFirstSignificantSubdomainCustomWithWWW(NULL, NULL, NULL);) 2025.04.02 01:50:11.934045 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWW doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:11.957256 [ 7799 ] {0f93e420-3249-47e9-9c09-ce0bdc3d7249} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWWRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC(NULL, NULL, NULL);) 2025.04.02 01:50:11.961248 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWWRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:11.985048 [ 7799 ] {b94b7920-08da-4d57-8d5e-9fb731212ac6} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutToFirstSignificantSubdomainRFC(NULL, NULL, NULL);) 2025.04.02 01:50:11.989446 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:12.013118 [ 7799 ] {b9652a6a-8f9c-437d-bb0d-0be3c8018e00} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutToFirstSignificantSubdomainWithWWW(NULL, NULL, NULL);) 2025.04.02 01:50:12.017474 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:12.046889 [ 7799 ] {e97972bb-253a-4d41-8923-56ec7a0069d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutToFirstSignificantSubdomainWithWWWRFC(NULL, NULL, NULL);) 2025.04.02 01:50:12.050919 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:12.076433 [ 7799 ] {bfee27df-364f-44d7-8071-7b727362db57} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutURLParameter doesn't match: passed 3, should be 2: In scope SELECT cutURLParameter(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutURLParameter(NULL, NULL, NULL);) 2025.04.02 01:50:12.080487 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutURLParameter doesn't match: passed 3, should be 2: In scope SELECT cutURLParameter(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:12.105578 [ 7799 ] {570972da-cce8-4a9f-9e81-53f4c2b3e13d} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 3, should be 1: In scope SELECT cutWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT cutWWW(NULL, NULL, NULL);) 2025.04.02 01:50:12.109783 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 3, should be 1: In scope SELECT cutWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:12.134679 [ 7799 ] {f14aa630-a72b-4b4d-bb9c-831f9dbf8279} executeQuery: Code: 42. DB::Exception: Number of arguments for function damerauLevenshteinDistance doesn't match: passed 3, should be 2: In scope SELECT damerauLevenshteinDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT damerauLevenshteinDistance(NULL, NULL, NULL);) 2025.04.02 01:50:12.138532 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function damerauLevenshteinDistance doesn't match: passed 3, should be 2: In scope SELECT damerauLevenshteinDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:12.248883 [ 7799 ] {d4e4d645-7671-4a16-bcf1-c7b81bceeb34} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTime64ToSnowflake(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dateTime64ToSnowflake(NULL, NULL, NULL);) 2025.04.02 01:50:12.253010 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTime64ToSnowflake(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:12.321074 [ 7799 ] {55970288-a808-4423-9d0d-b0bd80e5f742} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTimeToSnowflake(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dateTimeToSnowflake(NULL, NULL, NULL);) 2025.04.02 01:50:12.325253 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTimeToSnowflake(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:12.533398 [ 7799 ] {b4e8d099-46c8-4d50-9c6d-6d942f49118c} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeHTMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT decodeHTMLComponent(NULL, NULL, NULL);) 2025.04.02 01:50:12.538538 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeHTMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:12.568464 [ 7799 ] {1e222abe-62d6-42c0-941f-bcf7e20fc16a} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT decodeURLComponent(NULL, NULL, NULL);) 2025.04.02 01:50:12.573710 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:12.603942 [ 7799 ] {ed0ab96a-1f93-43e6-bb6f-673a553f1e6e} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLFormComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT decodeURLFormComponent(NULL, NULL, NULL);) 2025.04.02 01:50:12.609534 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLFormComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:12.639781 [ 7799 ] {7351c703-5af9-44ec-8599-887d0df8750a} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeXMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT decodeXMLComponent(NULL, NULL, NULL);) 2025.04.02 01:50:12.644830 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeXMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:12.717865 [ 7799 ] {1d94e804-939b-4d26-9e62-b025ebb08718} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 3, should be 0: In scope SELECT defaultProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT defaultProfiles(NULL, NULL, NULL);) 2025.04.02 01:50:12.722549 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 3, should be 0: In scope SELECT defaultProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:12.752638 [ 7799 ] {4568de6e-a98f-4111-b37d-140f70ec472e} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 3, should be 0: In scope SELECT defaultRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT defaultRoles(NULL, NULL, NULL);) 2025.04.02 01:50:12.757230 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 3, should be 0: In scope SELECT defaultRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:12.784947 [ 7799 ] {1be696d2-8248-4608-82ff-e1ba6774da2f} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfArgumentType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT defaultValueOfArgumentType(NULL, NULL, NULL);) 2025.04.02 01:50:12.789615 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfArgumentType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:12.817666 [ 7799 ] {44fee45e-22f4-47c0-bdcd-27a2cd0f10ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT defaultValueOfTypeName(NULL, NULL, NULL);) 2025.04.02 01:50:12.822247 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:12.850717 [ 7799 ] {b57f1879-ef77-4c55-94f6-f9c5083f8b51} executeQuery: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 3, should be 1: In scope SELECT degrees(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT degrees(NULL, NULL, NULL);) 2025.04.02 01:50:12.855159 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 3, should be 1: In scope SELECT degrees(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:12.881380 [ 7799 ] {c8d24a5b-8025-4759-a75b-aaa5d5ca1627} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT deltaSum(NULL, NULL, NULL);) 2025.04.02 01:50:12.885722 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:12.911902 [ 7799 ] {b104af3e-7456-4e1b-a1f3-939170e918b6} executeQuery: Code: 42. DB::Exception: Aggregate function deltaSumTimestamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT deltaSumTimestamp(NULL, NULL, NULL);) 2025.04.02 01:50:12.916210 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function deltaSumTimestamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:12.942780 [ 7799 ] {d6d60da0-2eb7-4a59-a42a-d1cdb5674bc3} executeQuery: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 3, should be 1: In scope SELECT demangle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT demangle(NULL, NULL, NULL);) 2025.04.02 01:50:12.947252 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 3, should be 1: In scope SELECT demangle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:12.990069 [ 7799 ] {27eb3371-8898-4609-a3b0-9aca2b542b0b} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT denseRank(NULL, NULL, NULL);) 2025.04.02 01:50:12.995814 [ 7799 ] {} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.04.02 01:50:13.042708 [ 7799 ] {1fbcc9d1-e3ac-4117-97f4-43bae19e2ebb} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dense_rank(NULL, NULL, NULL);) 2025.04.02 01:50:13.048392 [ 7799 ] {} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.04.02 01:50:13.078646 [ 7799 ] {96f3c5de-7c42-4945-af57-f489b9d15f9a} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT detectCharset(NULL, NULL, NULL);) 2025.04.02 01:50:13.084523 [ 7799 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.04.02 01:50:13.110595 [ 7799 ] {b89ef725-921b-44ce-936b-5196d0d16ed5} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT detectLanguage(NULL, NULL, NULL);) 2025.04.02 01:50:13.114971 [ 7799 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.04.02 01:50:13.143028 [ 7799 ] {deabf9fb-21a4-4afc-a13c-8d0f80012d32} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT detectLanguageMixed(NULL, NULL, NULL);) 2025.04.02 01:50:13.147253 [ 7799 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.04.02 01:50:13.174356 [ 7799 ] {cc7dae9b-845a-4728-8e28-9082f84ec8a1} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT detectLanguageUnknown(NULL, NULL, NULL);) 2025.04.02 01:50:13.178689 [ 7799 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.04.02 01:50:13.203734 [ 7799 ] {0a5c4e06-247a-4833-9410-d3796ac24e95} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT detectProgrammingLanguage(NULL, NULL, NULL);) 2025.04.02 01:50:13.208146 [ 7799 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.04.02 01:50:13.233729 [ 7799 ] {eed8050d-54c8-459c-b8c8-6a7d6ecc0f6e} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT detectTonality(NULL, NULL, NULL);) 2025.04.02 01:50:13.238097 [ 7799 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.04.02 01:50:13.268469 [ 7799 ] {78c3aaa4-63da-436c-870e-8f47853ac6bf} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGet(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dictGet(NULL, NULL, NULL);) 2025.04.02 01:50:13.273824 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGet(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:13.303195 [ 7799 ] {2225f10e-34b6-4164-96db-5db2ad2d5ef1} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGetAll, expected a const string.: In scope SELECT dictGetAll(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dictGetAll(NULL, NULL, NULL);) 2025.04.02 01:50:13.308664 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGetAll, expected a const string.: In scope SELECT dictGetAll(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:13.334718 [ 7799 ] {dd0ea651-5375-4663-ba85-df98a9b52edb} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetChildren doesn't match: passed 3, should be 2: In scope SELECT dictGetChildren(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dictGetChildren(NULL, NULL, NULL);) 2025.04.02 01:50:13.340049 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetChildren doesn't match: passed 3, should be 2: In scope SELECT dictGetChildren(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:13.547251 [ 7799 ] {77169470-f8a7-4ce0-a3de-1f7dd54fb868} executeQuery: Code: 1. DB::Exception: Expected const String column: In scope SELECT dictGetDescendants(NULL, NULL, NULL). (UNSUPPORTED_METHOD) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dictGetDescendants(NULL, NULL, NULL);) 2025.04.02 01:50:13.551802 [ 7799 ] {} TCPHandler: Code: 1. DB::Exception: Expected const String column: In scope SELECT dictGetDescendants(NULL, NULL, NULL). (UNSUPPORTED_METHOD) 2025.04.02 01:50:13.745840 [ 7799 ] {0b63647d-0298-4d00-a7da-0b0b361352d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetHierarchy doesn't match: passed 3, should be 2: In scope SELECT dictGetHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dictGetHierarchy(NULL, NULL, NULL);) 2025.04.02 01:50:13.749714 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetHierarchy doesn't match: passed 3, should be 2: In scope SELECT dictGetHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:14.336589 [ 7799 ] {ae1f33e7-d622-430e-b3e3-4fe0e09b2b45} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dictGetOrDefault(NULL, NULL, NULL);) 2025.04.02 01:50:14.340903 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:14.366786 [ 7799 ] {b723c415-01d8-4cd4-89ba-804c7a3acf90} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetOrNull(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dictGetOrNull(NULL, NULL, NULL);) 2025.04.02 01:50:14.371260 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetOrNull(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:14.803626 [ 13514 ] {f917957e-cef8-4d70-bbcf-cce23431a2d6} executeQuery: Code: 36. DB::Exception: It does not make sense to have codec NONE along with other compression codecs: NONE, NONE. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52288) (comment: 01272_suspicious_codecs.sql) (in query: -- test what should not work CREATE TABLE codecs (a UInt8 CODEC(NONE, NONE)) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000892594a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:192: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool) const @ 0x000000004227fe4a 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:736: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779c9d6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:50:14.807810 [ 13514 ] {} TCPHandler: Code: 36. DB::Exception: It does not make sense to have codec NONE along with other compression codecs: NONE, NONE. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000892594a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:192: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool) const @ 0x000000004227fe4a 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:736: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779c9d6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:50:14.824871 [ 13514 ] {2ea2ae7e-5ca7-4792-800f-f8f9be3d70e4} executeQuery: Code: 36. DB::Exception: It does not make sense to have codec NONE along with other compression codecs: NONE, LZ4. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52288) (comment: 01272_suspicious_codecs.sql) (in query: CREATE TABLE codecs (a UInt8 CODEC(NONE, LZ4)) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000892594a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:192: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool) const @ 0x000000004227fe4a 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:736: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779c9d6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:50:14.828187 [ 13514 ] {} TCPHandler: Code: 36. DB::Exception: It does not make sense to have codec NONE along with other compression codecs: NONE, LZ4. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000892594a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:192: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool) const @ 0x000000004227fe4a 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:736: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779c9d6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:50:14.845915 [ 13514 ] {5ffd5828-e5f6-437d-9685-eacbda21d63c} executeQuery: Code: 36. DB::Exception: It does not make sense to have codec NONE along with other compression codecs: LZ4, NONE. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52288) (comment: 01272_suspicious_codecs.sql) (in query: CREATE TABLE codecs (a UInt8 CODEC(LZ4, NONE)) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000892594a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:192: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool) const @ 0x000000004227fe4a 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:736: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779c9d6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:50:14.849282 [ 13514 ] {} TCPHandler: Code: 36. DB::Exception: It does not make sense to have codec NONE along with other compression codecs: LZ4, NONE. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000892594a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:192: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool) const @ 0x000000004227fe4a 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:736: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779c9d6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:50:15.035395 [ 7799 ] {703de6c1-921c-4708-a7c2-12d16885b985} executeQuery: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 3, should be 0: In scope SELECT displayName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT displayName(NULL, NULL, NULL);) 2025.04.02 01:50:15.039471 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 3, should be 0: In scope SELECT displayName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:15.062362 [ 7799 ] {11412d2f-79a0-4015-ba48-da3bbb7d9ef1} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT distanceL1(NULL, NULL, NULL);) 2025.04.02 01:50:15.066460 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:15.091719 [ 7799 ] {84dec422-5e2d-41db-8e93-66e4d4d42681} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT distanceL2(NULL, NULL, NULL);) 2025.04.02 01:50:15.096451 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:15.121866 [ 7799 ] {71f2b788-3d40-4d9b-8276-b5be610cc1b3} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT distanceL2Squared(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT distanceL2Squared(NULL, NULL, NULL);) 2025.04.02 01:50:15.126473 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT distanceL2Squared(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:15.151178 [ 7799 ] {d2ad1d60-8c73-4751-9820-30c924625bc9} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT distanceLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT distanceLinf(NULL, NULL, NULL);) 2025.04.02 01:50:15.155770 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT distanceLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:15.334295 [ 13514 ] {6bafc8bd-92b1-4135-89e0-449af3557ec1} executeQuery: Code: 36. DB::Exception: The combination of compression codecs LZ4, LZ4 is meaningless, because it does not make sense to apply any transformations after generic compression algorithm. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52288) (comment: 01272_suspicious_codecs.sql) (in query: CREATE TABLE codecs (a UInt8 CODEC(LZ4, LZ4)) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000892594a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:237: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool) const @ 0x000000004228045e 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:736: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779c9d6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:50:15.337904 [ 13514 ] {} TCPHandler: Code: 36. DB::Exception: The combination of compression codecs LZ4, LZ4 is meaningless, because it does not make sense to apply any transformations after generic compression algorithm. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000892594a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:237: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool) const @ 0x000000004228045e 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:736: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779c9d6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:50:15.354620 [ 13514 ] {001f2d14-0220-4cab-900e-5426edc1890a} executeQuery: Code: 36. DB::Exception: The combination of compression codecs LZ4, ZSTD(1) is meaningless, because it does not make sense to apply any transformations after generic compression algorithm. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52288) (comment: 01272_suspicious_codecs.sql) (in query: CREATE TABLE codecs (a UInt8 CODEC(LZ4, ZSTD)) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000892594a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:237: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool) const @ 0x000000004228045e 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:736: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779c9d6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:50:15.357874 [ 13514 ] {} TCPHandler: Code: 36. DB::Exception: The combination of compression codecs LZ4, ZSTD(1) is meaningless, because it does not make sense to apply any transformations after generic compression algorithm. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000892594a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:237: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool) const @ 0x000000004228045e 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:736: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779c9d6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:50:15.386856 [ 7799 ] {4656b6ba-1c60-44f2-991e-ac871a8b4ee8} executeQuery: Code: 42. DB::Exception: Number of arguments for function divide doesn't match: passed 3, should be 2: In scope SELECT divide(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT divide(NULL, NULL, NULL);) 2025.04.02 01:50:15.391025 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function divide doesn't match: passed 3, should be 2: In scope SELECT divide(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:15.457746 [ 7799 ] {11bc7335-495c-4588-bb39-5c55e6da20c3} executeQuery: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 3, should be 1: In scope SELECT domain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT domain(NULL, NULL, NULL);) 2025.04.02 01:50:15.462036 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 3, should be 1: In scope SELECT domain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:15.496763 [ 7799 ] {2d834ce8-9b84-453f-8942-32ef06854842} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 3, should be 1: In scope SELECT domainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT domainRFC(NULL, NULL, NULL);) 2025.04.02 01:50:15.501194 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 3, should be 1: In scope SELECT domainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:15.526874 [ 7799 ] {6940bfc2-2083-41d5-a5c2-06ee967f25da} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT domainWithoutWWW(NULL, NULL, NULL);) 2025.04.02 01:50:15.530980 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:15.556621 [ 7799 ] {5deccbe0-e500-421a-a0ca-cba27bfff124} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT domainWithoutWWWRFC(NULL, NULL, NULL);) 2025.04.02 01:50:15.561024 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:15.587194 [ 7799 ] {f10809f6-f482-4a0d-9910-00c538e8e0a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT dotProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dotProduct(NULL, NULL, NULL);) 2025.04.02 01:50:15.591348 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT dotProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:15.616690 [ 7799 ] {12a2e215-f292-4d5a-a783-f3986d9d3f2e} executeQuery: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 3, should be 1: In scope SELECT dumpColumnStructure(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dumpColumnStructure(NULL, NULL, NULL);) 2025.04.02 01:50:15.620900 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 3, should be 1: In scope SELECT dumpColumnStructure(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:15.647216 [ 7799 ] {364f6a45-5a56-40dd-a476-43f653cb9bb2} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicElement doesn't match: passed 3, should be 2: In scope SELECT dynamicElement(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dynamicElement(NULL, NULL, NULL);) 2025.04.02 01:50:15.651228 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicElement doesn't match: passed 3, should be 2: In scope SELECT dynamicElement(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:15.675605 [ 7799 ] {9ced1a87-c6e7-40fc-af30-c7b45e746994} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 3, should be 1: In scope SELECT dynamicType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT dynamicType(NULL, NULL, NULL);) 2025.04.02 01:50:15.679963 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 3, should be 1: In scope SELECT dynamicType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:15.704177 [ 7799 ] {9eccc04a-bc38-4517-9e47-c29d526554d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 3, should be 0: In scope SELECT e(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT e(NULL, NULL, NULL);) 2025.04.02 01:50:15.708446 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 3, should be 0: In scope SELECT e(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:15.733861 [ 7799 ] {94c4387f-4b44-4bd3-bfd1-d7f573e4c248} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT editDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT editDistance(NULL, NULL, NULL);) 2025.04.02 01:50:15.737985 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT editDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:15.767587 [ 7799 ] {1b19bbbd-c293-48d4-9ca6-a14465d6e49a} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT editDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT editDistanceUTF8(NULL, NULL, NULL);) 2025.04.02 01:50:15.772325 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT editDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:15.800249 [ 7799 ] {7fd3813b-de59-4a3b-9241-483306e10716} executeQuery: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 3, should be 1: In scope SELECT empty(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT empty(NULL, NULL, NULL);) 2025.04.02 01:50:15.804949 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 3, should be 1: In scope SELECT empty(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:15.827338 [ 13514 ] {75ce3427-6777-4b77-8367-a8a17ad43073} executeQuery: Code: 36. DB::Exception: Compression codec Delta(1) does not compress anything. You may want to add generic compression algorithm after other transformations, like: Delta(1), LZ4. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52288) (comment: 01272_suspicious_codecs.sql) (in query: CREATE TABLE codecs (a UInt8 CODEC(Delta)) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001b5fa9cd 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:201: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool) const @ 0x000000004227ff98 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:736: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779c9d6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:50:15.830765 [ 13514 ] {} TCPHandler: Code: 36. DB::Exception: Compression codec Delta(1) does not compress anything. You may want to add generic compression algorithm after other transformations, like: Delta(1), LZ4. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001b5fa9cd 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:201: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool) const @ 0x000000004227ff98 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:736: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779c9d6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:50:15.833715 [ 7799 ] {9cb8bc2e-8e06-498b-8f6c-9c8e5ba3205e} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayDate(NULL, NULL, NULL);) 2025.04.02 01:50:15.838726 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:15.846827 [ 13514 ] {eebcd13e-e969-4f7d-af8f-9d8d515e2f26} executeQuery: Code: 36. DB::Exception: Compression codec Delta(1), Delta(1) does not compress anything. You may want to add generic compression algorithm after other transformations, like: Delta(1), Delta(1), LZ4. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52288) (comment: 01272_suspicious_codecs.sql) (in query: CREATE TABLE codecs (a UInt8 CODEC(Delta, Delta)) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001b5fa9cd 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:201: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool) const @ 0x000000004227ff98 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:736: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779c9d6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:50:15.850120 [ 13514 ] {} TCPHandler: Code: 36. DB::Exception: Compression codec Delta(1), Delta(1) does not compress anything. You may want to add generic compression algorithm after other transformations, like: Delta(1), Delta(1), LZ4. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001b5fa9cd 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:201: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool) const @ 0x000000004227ff98 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:736: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779c9d6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:50:15.867536 [ 13514 ] {7940b58d-b3d9-4bbd-8d37-b06b958df6c8} executeQuery: Code: 36. DB::Exception: The combination of compression codecs LZ4, Delta(1) is meaningless, because it does not make sense to apply any transformations after generic compression algorithm. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52288) (comment: 01272_suspicious_codecs.sql) (in query: CREATE TABLE codecs (a UInt8 CODEC(LZ4, Delta)) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000892594a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:237: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool) const @ 0x000000004228045e 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:736: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779c9d6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:50:15.867905 [ 7799 ] {be647ac9-b1b9-4355-8d7b-2c46c4d04bda} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDateTime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayDateTime(NULL, NULL, NULL);) 2025.04.02 01:50:15.871675 [ 13514 ] {} TCPHandler: Code: 36. DB::Exception: The combination of compression codecs LZ4, Delta(1) is meaningless, because it does not make sense to apply any transformations after generic compression algorithm. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000892594a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:237: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool) const @ 0x000000004228045e 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:736: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779c9d6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:50:15.873163 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDateTime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:15.902723 [ 7799 ] {44214bad-953d-4b5f-8907-937e57484dbb} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayFloat32(NULL, NULL, NULL);) 2025.04.02 01:50:15.908054 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:15.932146 [ 7799 ] {7b27a838-fb9a-4aa4-81b7-810a6c0ee57f} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayFloat64(NULL, NULL, NULL);) 2025.04.02 01:50:15.936674 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:15.960211 [ 7799 ] {c6715142-2708-43f0-8417-31a0300b7704} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayInt16(NULL, NULL, NULL);) 2025.04.02 01:50:15.964505 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:15.989296 [ 7799 ] {d406ff97-a28b-4b67-97e4-f1c5326fe5d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayInt32(NULL, NULL, NULL);) 2025.04.02 01:50:15.994049 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:16.019825 [ 7799 ] {13525d02-6ff0-44e4-8b99-8e3ab2fb06d9} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayInt64(NULL, NULL, NULL);) 2025.04.02 01:50:16.024362 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:16.048796 [ 7799 ] {34f5d592-0e0b-4c93-b9fd-0c2090a5455b} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayInt8(NULL, NULL, NULL);) 2025.04.02 01:50:16.053406 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:16.080751 [ 7799 ] {967d9b7f-7aff-4387-ad63-6d7ae88a559b} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 3, should be 0: In scope SELECT emptyArrayString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayString(NULL, NULL, NULL);) 2025.04.02 01:50:16.085627 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 3, should be 0: In scope SELECT emptyArrayString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:16.111200 [ 7799 ] {e9758d4a-ddf3-4549-95f9-7c6a3cadc73b} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 3, should be 1: In scope SELECT emptyArrayToSingle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayToSingle(NULL, NULL, NULL);) 2025.04.02 01:50:16.116404 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 3, should be 1: In scope SELECT emptyArrayToSingle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:16.146301 [ 7799 ] {de23055f-960d-4b7c-a25f-9d8574f27e91} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayUInt16(NULL, NULL, NULL);) 2025.04.02 01:50:16.150949 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:16.178663 [ 7799 ] {804a39a9-e097-4840-bf5b-325fab9da6e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayUInt32(NULL, NULL, NULL);) 2025.04.02 01:50:16.183420 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:16.212440 [ 7799 ] {f390e512-cb75-48b2-a215-59f3d9526cf8} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayUInt64(NULL, NULL, NULL);) 2025.04.02 01:50:16.216907 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:16.242686 [ 7799 ] {790ee258-1fa2-4ae3-af06-074cd3ce25d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT emptyArrayUInt8(NULL, NULL, NULL);) 2025.04.02 01:50:16.249973 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:16.274004 [ 7799 ] {523c65a1-6d89-4ea0-b8ee-93b604cd63c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 3, should be 0: In scope SELECT enabledProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT enabledProfiles(NULL, NULL, NULL);) 2025.04.02 01:50:16.278492 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 3, should be 0: In scope SELECT enabledProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:16.308541 [ 7799 ] {453bdfe0-2f1c-482a-8c4d-90dc46b08404} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 3, should be 0: In scope SELECT enabledRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT enabledRoles(NULL, NULL, NULL);) 2025.04.02 01:50:16.313095 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 3, should be 0: In scope SELECT enabledRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:16.341198 [ 7799 ] {56ab0a93-9c2f-48b9-bc1f-f5995d35d803} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT encodeURLComponent(NULL, NULL, NULL);) 2025.04.02 01:50:16.346085 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:16.371337 [ 13514 ] {53f52935-5759-48a2-a275-e792cb147b55} executeQuery: Code: 36. DB::Exception: The combination of compression codecs Gorilla is meaningless, because it does not make sense to apply a floating-point time series codec to non-floating-point columns (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52288) (comment: 01272_suspicious_codecs.sql) (in query: CREATE TABLE codecs (a UInt8 CODEC(Gorilla)) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000892594a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:219: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool) const @ 0x00000000422805a9 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:736: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779c9d6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:50:16.372556 [ 7799 ] {dde330ca-d2f8-4518-a030-aa8bda0bb92d} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLFormComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT encodeURLFormComponent(NULL, NULL, NULL);) 2025.04.02 01:50:16.375743 [ 13514 ] {} TCPHandler: Code: 36. DB::Exception: The combination of compression codecs Gorilla is meaningless, because it does not make sense to apply a floating-point time series codec to non-floating-point columns (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000892594a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:219: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool) const @ 0x00000000422805a9 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:736: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779c9d6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:50:16.377375 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLFormComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:16.393282 [ 13514 ] {f8120dda-78c9-43ac-9e69-a19a5322cd0b} executeQuery: Code: 36. DB::Exception: The combination of compression codecs Gorilla is meaningless, because it does not make sense to apply a floating-point time series codec to non-floating-point columns (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52288) (comment: 01272_suspicious_codecs.sql) (in query: CREATE TABLE codecs (a FixedString(2) CODEC(Gorilla)) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000892594a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:219: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool) const @ 0x00000000422805a9 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:736: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779c9d6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:50:16.396682 [ 13514 ] {} TCPHandler: Code: 36. DB::Exception: The combination of compression codecs Gorilla is meaningless, because it does not make sense to apply a floating-point time series codec to non-floating-point columns (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000892594a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:219: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool) const @ 0x00000000422805a9 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:736: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779c9d6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:50:16.404150 [ 7799 ] {74821890-82fa-4368-9a05-bcc9a882bc23} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeXMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT encodeXMLComponent(NULL, NULL, NULL);) 2025.04.02 01:50:16.408942 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeXMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:16.412150 [ 13514 ] {8ecc1931-d0fb-49ac-a138-15b9973da495} executeQuery: Code: 36. DB::Exception: The combination of compression codecs Gorilla is meaningless, because it does not make sense to apply a floating-point time series codec to non-floating-point columns (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52288) (comment: 01272_suspicious_codecs.sql) (in query: CREATE TABLE codecs (a Decimal(15,5) CODEC(Gorilla)) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000892594a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:219: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool) const @ 0x00000000422805a9 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:736: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779c9d6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:50:16.416028 [ 13514 ] {} TCPHandler: Code: 36. DB::Exception: The combination of compression codecs Gorilla is meaningless, because it does not make sense to apply a floating-point time series codec to non-floating-point columns (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000892594a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:219: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool) const @ 0x00000000422805a9 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:736: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779c9d6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:50:16.480091 [ 7799 ] {0f07324c-0103-4637-9bd6-6bc576ed6b33} executeQuery: Code: 42. DB::Exception: Number of arguments for function endsWith doesn't match: passed 3, should be 2: In scope SELECT endsWith(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT endsWith(NULL, NULL, NULL);) 2025.04.02 01:50:16.484619 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function endsWith doesn't match: passed 3, should be 2: In scope SELECT endsWith(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:16.508563 [ 7799 ] {89409451-e6c5-4ba0-94e4-602d6d975230} executeQuery: Code: 42. DB::Exception: Number of arguments for function endsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT endsWithUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT endsWithUTF8(NULL, NULL, NULL);) 2025.04.02 01:50:16.513195 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function endsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT endsWithUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:16.595552 [ 7799 ] {f6b991b5-a2ee-4950-a96c-c4207adeb531} executeQuery: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 3, should be 2: In scope SELECT equals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT equals(NULL, NULL, NULL);) 2025.04.02 01:50:16.600043 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 3, should be 2: In scope SELECT equals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:16.631298 [ 7799 ] {59cba2d5-62cc-4b71-8a64-6dc51e3d2f24} executeQuery: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 3, should be 1: In scope SELECT erf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT erf(NULL, NULL, NULL);) 2025.04.02 01:50:16.636619 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 3, should be 1: In scope SELECT erf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:16.659977 [ 7799 ] {ac2f7bee-e597-4005-8a33-37f5da6d1a55} executeQuery: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 3, should be 1: In scope SELECT erfc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT erfc(NULL, NULL, NULL);) 2025.04.02 01:50:16.668519 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 3, should be 1: In scope SELECT erfc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:16.688295 [ 7799 ] {02e34e60-a2a0-46fc-82e5-a95653b6994d} executeQuery: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 3, should be 1: In scope SELECT errorCodeToName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT errorCodeToName(NULL, NULL, NULL);) 2025.04.02 01:50:16.698856 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 3, should be 1: In scope SELECT errorCodeToName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:16.761875 [ 7799 ] {4088247a-09e5-4bda-80ef-b99fcc92b00d} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 3, should be 1: In scope SELECT exp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT exp(NULL, NULL, NULL);) 2025.04.02 01:50:16.766086 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 3, should be 1: In scope SELECT exp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:16.790617 [ 7799 ] {d76b5112-f82b-4a33-b2d4-5721ceed7126} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 3, should be 1: In scope SELECT exp10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT exp10(NULL, NULL, NULL);) 2025.04.02 01:50:16.796071 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 3, should be 1: In scope SELECT exp10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:16.823555 [ 7799 ] {be072405-055f-45c9-8814-ba7614c819f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 3, should be 1: In scope SELECT exp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT exp2(NULL, NULL, NULL);) 2025.04.02 01:50:16.827999 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 3, should be 1: In scope SELECT exp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:16.898782 [ 13514 ] {3af35e71-65ed-4dea-ba1a-bcb25cb1db07} executeQuery: Code: 36. DB::Exception: The combination of compression codecs Delta(8), Gorilla is meaningless, because floating point time series codecs do delta compression implicitly by themselves. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52288) (comment: 01272_suspicious_codecs.sql) (in query: CREATE TABLE codecs (a Float64 CODEC(Delta, Gorilla)) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000892594a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:228: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool) const @ 0x0000000042280315 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:736: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779c9d6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:50:16.902123 [ 13514 ] {} TCPHandler: Code: 36. DB::Exception: The combination of compression codecs Delta(8), Gorilla is meaningless, because floating point time series codecs do delta compression implicitly by themselves. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000892594a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:228: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool) const @ 0x0000000042280315 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:736: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779c9d6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:50:16.907912 [ 7799 ] {013d611f-2664-459b-9e73-d792d18a9532} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT exponentialTimeDecayedAvg(NULL, NULL, NULL);) 2025.04.02 01:50:16.912874 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:16.918084 [ 13514 ] {37f47321-0337-4174-83f5-5a3eac9ea6c3} executeQuery: Code: 36. DB::Exception: The combination of compression codecs DoubleDelta, FPC(12) is meaningless, because floating point time series codecs do delta compression implicitly by themselves. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52288) (comment: 01272_suspicious_codecs.sql) (in query: CREATE TABLE codecs (a Float32 CODEC(DoubleDelta, FPC)) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000892594a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:228: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool) const @ 0x0000000042280315 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:736: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779c9d6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:50:16.921283 [ 13514 ] {} TCPHandler: Code: 36. DB::Exception: The combination of compression codecs DoubleDelta, FPC(12) is meaningless, because floating point time series codecs do delta compression implicitly by themselves. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000892594a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:228: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool) const @ 0x0000000042280315 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:736: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003779c9d6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:814: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000377a2425 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1668: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377cacaa 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 18. ? @ 0x00007f583d9b1ac3 19. ? @ 0x00007f583da43850 2025.04.02 01:50:16.938489 [ 7799 ] {14e2bad9-c73e-4e6e-ab8c-983dfcd8e10d} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT exponentialTimeDecayedCount(NULL, NULL, NULL);) 2025.04.02 01:50:16.943096 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:16.967446 [ 7799 ] {5663fb76-9905-4bbe-afb3-4d793bc99178} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT exponentialTimeDecayedMax(NULL, NULL, NULL);) 2025.04.02 01:50:16.971883 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:16.999372 [ 7799 ] {07f19d3d-409b-4b2b-a99d-05553db66e17} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT exponentialTimeDecayedSum(NULL, NULL, NULL);) 2025.04.02 01:50:17.004846 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:17.029342 [ 7799 ] {fe16722f-4459-489d-b308-1fe51b4cf88c} executeQuery: Code: 42. DB::Exception: Number of arguments for function extract doesn't match: passed 3, should be 2: In scope SELECT extract(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT extract(NULL, NULL, NULL);) 2025.04.02 01:50:17.033995 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extract doesn't match: passed 3, should be 2: In scope SELECT extract(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:17.057102 [ 7799 ] {e298988d-52dd-42fd-8b2b-f3b759dce9b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAll doesn't match: passed 3, should be 2: In scope SELECT extractAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT extractAll(NULL, NULL, NULL);) 2025.04.02 01:50:17.061385 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAll doesn't match: passed 3, should be 2: In scope SELECT extractAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:17.085416 [ 7799 ] {5af54db9-4570-4349-bda2-a7d314b7a5be} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroups(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT extractAllGroups(NULL, NULL, NULL);) 2025.04.02 01:50:17.089684 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroups(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:17.113531 [ 7799 ] {fd23a85b-c143-4044-bb51-991660a07c4d} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsHorizontal(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT extractAllGroupsHorizontal(NULL, NULL, NULL);) 2025.04.02 01:50:17.117914 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsHorizontal(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:17.141966 [ 7799 ] {abd8e87b-a3c4-400b-bec6-216003975522} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsVertical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT extractAllGroupsVertical(NULL, NULL, NULL);) 2025.04.02 01:50:17.146342 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsVertical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:17.172625 [ 7799 ] {4f855cee-7ad4-412b-bc9b-43989e59772e} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 3, should be 2: In scope SELECT extractGroups(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT extractGroups(NULL, NULL, NULL);) 2025.04.02 01:50:17.177133 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 3, should be 2: In scope SELECT extractGroups(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:17.302647 [ 7799 ] {4472cdc4-fd2c-4b84-af22-3c21b3cc5722} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 3, should be 1: In scope SELECT extractTextFromHTML(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT extractTextFromHTML(NULL, NULL, NULL);) 2025.04.02 01:50:17.307363 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 3, should be 1: In scope SELECT extractTextFromHTML(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:17.335130 [ 7799 ] {57939e4b-2045-49b9-b8de-7f83d5fb149e} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameter doesn't match: passed 3, should be 2: In scope SELECT extractURLParameter(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT extractURLParameter(NULL, NULL, NULL);) 2025.04.02 01:50:17.339594 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameter doesn't match: passed 3, should be 2: In scope SELECT extractURLParameter(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:17.367070 [ 7799 ] {05187784-01f8-4d7c-9e4d-feba92387b78} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 3, should be 1: In scope SELECT extractURLParameterNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT extractURLParameterNames(NULL, NULL, NULL);) 2025.04.02 01:50:17.371699 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 3, should be 1: In scope SELECT extractURLParameterNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:17.397646 [ 7799 ] {7fccf1cb-3fa6-4698-a614-061ddd14c308} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 3, should be 1: In scope SELECT extractURLParameters(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT extractURLParameters(NULL, NULL, NULL);) 2025.04.02 01:50:17.401981 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 3, should be 1: In scope SELECT extractURLParameters(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:17.426555 [ 7799 ] {20e829d8-572c-4caf-a78b-7490c10a2508} executeQuery: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 3, should be 1: In scope SELECT factorial(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT factorial(NULL, NULL, NULL);) 2025.04.02 01:50:17.430835 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 3, should be 1: In scope SELECT factorial(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:17.543243 [ 7799 ] {1fdd2d4c-e05b-4bf0-b287-60351d4b9b37} executeQuery: Code: 42. DB::Exception: Number of arguments for function file doesn't match: passed 3, should be 1 or 2: In scope SELECT file(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT file(NULL, NULL, NULL);) 2025.04.02 01:50:17.547553 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function file doesn't match: passed 3, should be 1 or 2: In scope SELECT file(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:17.700495 [ 7799 ] {b15bd625-9cd8-404a-885b-0b30e9c963d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 3, should be 1: In scope SELECT finalizeAggregation(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT finalizeAggregation(NULL, NULL, NULL);) 2025.04.02 01:50:17.704376 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 3, should be 1: In scope SELECT finalizeAggregation(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:17.728355 [ 7799 ] {41828c63-21ca-4160-85a2-88c7f7ecad73} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 3, should be 1: In scope SELECT firstLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT firstLine(NULL, NULL, NULL);) 2025.04.02 01:50:17.732384 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 3, should be 1: In scope SELECT firstLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:17.757595 [ 7799 ] {fea6ce93-414c-4967-923c-30db16eab85b} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT firstSignificantSubdomain(NULL, NULL, NULL);) 2025.04.02 01:50:17.761954 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:17.788909 [ 7799 ] {1f9c6129-d1a4-4ef6-a131-704d2fa253cf} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT firstSignificantSubdomainCustom(NULL, NULL, NULL);) 2025.04.02 01:50:17.793194 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:17.820225 [ 7799 ] {8965767a-87d7-47d6-a218-e606e4b13523} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustomRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT firstSignificantSubdomainCustomRFC(NULL, NULL, NULL);) 2025.04.02 01:50:17.825315 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustomRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:17.852267 [ 7799 ] {ac06c297-9efb-42d0-9637-df25a3dcdde9} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT firstSignificantSubdomainRFC(NULL, NULL, NULL);) 2025.04.02 01:50:17.857285 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:17.882095 [ 7799 ] {1630d650-22d2-4b9c-89d5-faa176759fd0} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT firstValueRespectNulls(NULL, NULL, NULL);) 2025.04.02 01:50:17.886549 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:17.965411 [ 7799 ] {880b1b12-016a-41d8-9fdd-7497ab134cff} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT first_value_respect_nulls(NULL, NULL, NULL);) 2025.04.02 01:50:17.970205 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:17.994683 [ 7799 ] {14e99cf6-b113-422f-9542-da65d071ce01} executeQuery: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT flameGraph(NULL, NULL, NULL);) 2025.04.02 01:50:17.999554 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:18.028350 [ 7799 ] {85dd4e8d-2f73-4135-9606-03e5eca1507d} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT flatten(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT flatten(NULL, NULL, NULL);) 2025.04.02 01:50:18.033911 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT flatten(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:18.057933 [ 7799 ] {2a1e52fe-5e24-4001-b1e7-0bc8852e4fb7} executeQuery: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 3, should be 1: In scope SELECT flattenTuple(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT flattenTuple(NULL, NULL, NULL);) 2025.04.02 01:50:18.062225 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 3, should be 1: In scope SELECT flattenTuple(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:18.259967 [ 7799 ] {ef29cdaf-c2df-4762-8daf-d30130edfb0c} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 3, should be 1: In scope SELECT formatQuery(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT formatQuery(NULL, NULL, NULL);) 2025.04.02 01:50:18.264525 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 3, should be 1: In scope SELECT formatQuery(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:18.293150 [ 7799 ] {3fc78c7a-5b50-42e7-978c-56f25b5199c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQueryOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT formatQueryOrNull(NULL, NULL, NULL);) 2025.04.02 01:50:18.298012 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQueryOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:18.324573 [ 7799 ] {db8f2a1c-ce67-4a00-84ec-11bc9cb5f312} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT formatQuerySingleLine(NULL, NULL, NULL);) 2025.04.02 01:50:18.329056 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:18.354539 [ 7799 ] {d29ae5bf-bec9-4de2-a713-ba42b2235c2c} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLineOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT formatQuerySingleLineOrNull(NULL, NULL, NULL);) 2025.04.02 01:50:18.359190 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLineOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:18.383152 [ 7799 ] {a981ce5b-1fe7-4940-93d0-84c9826ff82c} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableDecimalSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT formatReadableDecimalSize(NULL, NULL, NULL);) 2025.04.02 01:50:18.387536 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableDecimalSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:18.415165 [ 7799 ] {80a99adf-63e6-40b7-83a0-7c8bd1a39a6e} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 3, should be 1: In scope SELECT formatReadableQuantity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT formatReadableQuantity(NULL, NULL, NULL);) 2025.04.02 01:50:18.419345 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 3, should be 1: In scope SELECT formatReadableQuantity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:18.449811 [ 7799 ] {8d000ab8-8f96-4dfa-840a-454f9a50a10d} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT formatReadableSize(NULL, NULL, NULL);) 2025.04.02 01:50:18.455824 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:18.525449 [ 7799 ] {c0ba9331-260b-4876-a85d-69f756102880} executeQuery: Code: 43. DB::Exception: First argument to formatRow must be a format name: In scope SELECT formatRow(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT formatRow(NULL, NULL, NULL);) 2025.04.02 01:50:18.530078 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: First argument to formatRow must be a format name: In scope SELECT formatRow(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:18.555181 [ 7799 ] {fcca5da2-807d-4111-a826-4ec99b3032a1} executeQuery: Code: 43. DB::Exception: First argument to formatRowNoNewline must be a format name: In scope SELECT formatRowNoNewline(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT formatRowNoNewline(NULL, NULL, NULL);) 2025.04.02 01:50:18.559538 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: First argument to formatRowNoNewline must be a format name: In scope SELECT formatRowNoNewline(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:18.585595 [ 7799 ] {669d21c5-c526-4592-9a4d-2290e959e9cc} executeQuery: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 3, should be 1: In scope SELECT fragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT fragment(NULL, NULL, NULL);) 2025.04.02 01:50:18.589831 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 3, should be 1: In scope SELECT fragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:18.615167 [ 7799 ] {49968338-0604-4a92-b993-7cd90f744be9} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT fromDaysSinceYearZero(NULL, NULL, NULL);) 2025.04.02 01:50:18.619497 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:18.644455 [ 7799 ] {4e116ca2-6d2e-4c31-a2ce-3bca903cd6e2} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT fromDaysSinceYearZero32(NULL, NULL, NULL);) 2025.04.02 01:50:18.648746 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:18.674414 [ 7799 ] {ed7e2ff9-0190-4f2f-994b-81d7f8e46a75} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT fromModifiedJulianDay(NULL, NULL, NULL);) 2025.04.02 01:50:18.679065 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:18.705277 [ 7799 ] {e4d552d6-1d65-4254-9ca9-add803e4e252} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDayOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT fromModifiedJulianDayOrNull(NULL, NULL, NULL);) 2025.04.02 01:50:18.710058 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDayOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:18.734905 [ 7799 ] {0440e6ef-e365-4fc3-89a3-c80be1eee8d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT fromUTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT fromUTCTimestamp(NULL, NULL, NULL);) 2025.04.02 01:50:18.739503 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT fromUTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:18.968810 [ 13512 ] {6a794b3c-952c-4b6e-ab51-3f35d37ab2d9} executeQuery: Code: 43. DB::Exception: Illegal type Array(Variant(Tuple(UInt8, UInt8))) expression, must be numeric type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52482) (comment: 03203_variant_convert_field_to_type_bug.sql) (in query: SELECT * FROM numbers([tuple(1, 2), NULL], 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:105: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x00000000273b5f6d 5. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:79: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000273b359b 6. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000032dd63f1 7. ./build_docker/./src/Interpreters/Context.cpp:2365: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000036542f3f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4956: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000035d4d991 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5295: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000035ddf701 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5552: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24c93 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 21. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 22. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 28. ? @ 0x00007f583d9b1ac3 29. ? @ 0x00007f583da43850 2025.04.02 01:50:18.972868 [ 13512 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Variant(Tuple(UInt8, UInt8))) expression, must be numeric type. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:105: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x00000000273b5f6d 5. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:79: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000273b359b 6. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000032dd63f1 7. ./build_docker/./src/Interpreters/Context.cpp:2365: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000036542f3f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4956: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000035d4d991 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5295: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000035ddf701 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5552: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24c93 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 21. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 22. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 28. ? @ 0x00007f583d9b1ac3 29. ? @ 0x00007f583da43850 2025.04.02 01:50:19.032947 [ 7799 ] {1bc04a64-1e09-461d-b1d0-246556249a34} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT from_utc_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT from_utc_timestamp(NULL, NULL, NULL);) 2025.04.02 01:50:19.037730 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT from_utc_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:19.065797 [ 7799 ] {db675264-0b44-4df0-a052-d05954b6b60c} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT fullHostName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT fullHostName(NULL, NULL, NULL);) 2025.04.02 01:50:19.070539 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT fullHostName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:19.098867 [ 7799 ] {aacbb551-0b38-4977-b70f-584e411a2f77} executeQuery: Code: 42. DB::Exception: Number of arguments for function fuzzBits doesn't match: passed 3, should be 2: In scope SELECT fuzzBits(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT fuzzBits(NULL, NULL, NULL);) 2025.04.02 01:50:19.103224 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fuzzBits doesn't match: passed 3, should be 2: In scope SELECT fuzzBits(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:19.174894 [ 7799 ] {6959c0b7-a83c-4594-bd84-e8d80d4056ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function gcd doesn't match: passed 3, should be 2: In scope SELECT gcd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT gcd(NULL, NULL, NULL);) 2025.04.02 01:50:19.179890 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function gcd doesn't match: passed 3, should be 2: In scope SELECT gcd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:19.206164 [ 7799 ] {f3cea6d1-4a5a-4d4e-b800-301a4830df7e} executeQuery: Code: 42. DB::Exception: Number of arguments for function generateRandomStructure doesn't match: passed 3, expected from 0 to 2: In scope SELECT generateRandomStructure(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT generateRandomStructure(NULL, NULL, NULL);) 2025.04.02 01:50:19.211432 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function generateRandomStructure doesn't match: passed 3, expected from 0 to 2: In scope SELECT generateRandomStructure(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:19.237229 [ 7799 ] {fe2c6126-1617-42a9-a3cf-a22184152626} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateSnowflakeID'. Expected 2 optional arguments, got 3 arguments: In scope SELECT generateSnowflakeID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT generateSnowflakeID(NULL, NULL, NULL);) 2025.04.02 01:50:19.242083 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateSnowflakeID'. Expected 2 optional arguments, got 3 arguments: In scope SELECT generateSnowflakeID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:19.319429 [ 7799 ] {6bd86f67-5cf0-40ca-b346-0872864615cd} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv4'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv4(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT generateUUIDv4(NULL, NULL, NULL);) 2025.04.02 01:50:19.323668 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv4'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv4(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:19.345537 [ 7799 ] {fb4dff8b-5012-4d90-8c8b-ca010ff77c6e} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv7'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv7(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT generateUUIDv7(NULL, NULL, NULL);) 2025.04.02 01:50:19.349438 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv7'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv7(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:19.371577 [ 7799 ] {c6b08fb9-e35d-4808-a456-7692b156bfd9} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 3, should be 4: In scope SELECT geoDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT geoDistance(NULL, NULL, NULL);) 2025.04.02 01:50:19.375882 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 3, should be 4: In scope SELECT geoDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:19.435804 [ 14191 ] {b4abaed8-c860-4b86-bcf6-384a862ad1a3} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 1048577 ('-'): -. Max query size exceeded: '-'. (SYNTAX_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48470) (in query: select 1 in (1, 1, ... (truncated 948624 characters)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000895329e 3. ./build_docker/./src/Parsers/parseQuery.cpp:405: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c84a 4. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 5. ./build_docker/./src/Interpreters/executeQuery.cpp:876: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003926dc04 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1667: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000039288b06 7. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003f279970 8. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003f285729 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003f4a8b63 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:50:19.438194 [ 14191 ] {b4abaed8-c860-4b86-bcf6-384a862ad1a3} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 1048577 ('-'): -. Max query size exceeded: '-'. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000895329e 3. ./build_docker/./src/Parsers/parseQuery.cpp:405: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000004270c84a 4. ./build_docker/./src/Parsers/parseQuery.cpp:418: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000004270c991 5. ./build_docker/./src/Interpreters/executeQuery.cpp:876: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003926dc04 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1667: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000039288b06 7. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003f279970 8. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003f285729 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003f4a8b63 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:50:19.441922 [ 7799 ] {2a8b09bb-a8ee-4419-8856-a5f3bc985a91} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoToS2 doesn't match: passed 3, should be 2: In scope SELECT geoToS2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT geoToS2(NULL, NULL, NULL);) 2025.04.02 01:50:19.446292 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoToS2 doesn't match: passed 3, should be 2: In scope SELECT geoToS2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:19.472325 [ 7799 ] {8b24d648-1718-4da8-b229-ad7cbfbd0c13} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 3, should be 1: In scope SELECT geohashDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT geohashDecode(NULL, NULL, NULL);) 2025.04.02 01:50:19.476763 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 3, should be 1: In scope SELECT geohashDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:19.548200 [ 7799 ] {c9bd8cbb-b92d-439a-8ecf-7a09e46d1736} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 3, should be 5: In scope SELECT geohashesInBox(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT geohashesInBox(NULL, NULL, NULL);) 2025.04.02 01:50:19.552396 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 3, should be 5: In scope SELECT geohashesInBox(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:19.576891 [ 7799 ] {07697f57-7ded-4b6a-9061-d9a7dc5fcbf8} executeQuery: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT getClientHTTPHeader(NULL, NULL, NULL);) 2025.04.02 01:50:19.581256 [ 7799 ] {} TCPHandler: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) 2025.04.02 01:50:19.605416 [ 7799 ] {56c96e02-dc75-4e88-b9e1-35bfe81a1396} executeQuery: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 3, should be 1: In scope SELECT getMacro(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT getMacro(NULL, NULL, NULL);) 2025.04.02 01:50:19.609711 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 3, should be 1: In scope SELECT getMacro(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:19.636908 [ 7799 ] {6a5b3f43-a155-49d5-836b-93f18da27885} executeQuery: Code: 42. DB::Exception: Number of arguments for function getMaxTableNameLengthForDatabase doesn't match: passed 3, should be 1: In scope SELECT getMaxTableNameLengthForDatabase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT getMaxTableNameLengthForDatabase(NULL, NULL, NULL);) 2025.04.02 01:50:19.641432 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getMaxTableNameLengthForDatabase doesn't match: passed 3, should be 1: In scope SELECT getMaxTableNameLengthForDatabase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:19.666932 [ 7799 ] {dd8b5072-ccdc-48b0-81d2-062ddb0ae0e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 3, should be 0: In scope SELECT getOSKernelVersion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT getOSKernelVersion(NULL, NULL, NULL);) 2025.04.02 01:50:19.671305 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 3, should be 0: In scope SELECT getOSKernelVersion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:19.698553 [ 7799 ] {d7405d95-a378-4f24-8078-c9cec3b50444} executeQuery: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 3, should be 1: In scope SELECT getServerPort(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT getServerPort(NULL, NULL, NULL);) 2025.04.02 01:50:19.702801 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 3, should be 1: In scope SELECT getServerPort(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:19.728241 [ 7799 ] {fb871185-6a4a-4104-a2cf-c3ce6c5aa842} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 3, should be 1: In scope SELECT getSetting(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT getSetting(NULL, NULL, NULL);) 2025.04.02 01:50:19.732836 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 3, should be 1: In scope SELECT getSetting(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:19.756123 [ 7799 ] {d3244472-1882-4770-b429-2c56bcbcd7dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSettingOrDefault doesn't match: passed 3, should be 2: In scope SELECT getSettingOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT getSettingOrDefault(NULL, NULL, NULL);) 2025.04.02 01:50:19.760319 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSettingOrDefault doesn't match: passed 3, should be 2: In scope SELECT getSettingOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:19.784609 [ 7799 ] {36cc623e-5522-4432-9659-7b8ef2cb1854} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 3, should be 1: In scope SELECT getSizeOfEnumType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT getSizeOfEnumType(NULL, NULL, NULL);) 2025.04.02 01:50:19.788996 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 3, should be 1: In scope SELECT getSizeOfEnumType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:19.815410 [ 7799 ] {61ecb5e6-26d3-469e-a6bd-810d8624ff0a} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSubcolumn doesn't match: passed 3, should be 2: In scope SELECT getSubcolumn(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT getSubcolumn(NULL, NULL, NULL);) 2025.04.02 01:50:19.819632 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSubcolumn doesn't match: passed 3, should be 2: In scope SELECT getSubcolumn(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:19.845192 [ 7799 ] {d28f0ad3-ef9e-4a2a-b9f3-30692b5b7307} executeQuery: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 3, should be 1: In scope SELECT getTypeSerializationStreams(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT getTypeSerializationStreams(NULL, NULL, NULL);) 2025.04.02 01:50:19.849358 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 3, should be 1: In scope SELECT getTypeSerializationStreams(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:19.873733 [ 7799 ] {243e9ab6-f7e9-4dcd-9ecb-234a3e5be5a8} executeQuery: Code: 42. DB::Exception: Function 'globalIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT globalIn(NULL, NULL, NULL);) 2025.04.02 01:50:19.878378 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:19.902618 [ 7799 ] {e6c82f84-1de6-45b9-af48-de9f0b2f919f} executeQuery: Code: 42. DB::Exception: Function 'globalInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT globalInIgnoreSet(NULL, NULL, NULL);) 2025.04.02 01:50:19.906966 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:19.931377 [ 7799 ] {19906be3-c244-4fd5-92cb-61c9b95c0a96} executeQuery: Code: 42. DB::Exception: Function 'globalNotIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT globalNotIn(NULL, NULL, NULL);) 2025.04.02 01:50:19.936461 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:19.961001 [ 7799 ] {f1ce91b8-fd02-47ac-8711-df3677e42f27} executeQuery: Code: 42. DB::Exception: Function 'globalNotInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT globalNotInIgnoreSet(NULL, NULL, NULL);) 2025.04.02 01:50:19.965486 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:19.989291 [ 7799 ] {647861da-8ef3-4ace-b5c4-9f8811aebe7c} executeQuery: Code: 42. DB::Exception: Function 'globalNotNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT globalNotNullIn(NULL, NULL, NULL);) 2025.04.02 01:50:19.994015 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:20.018166 [ 7799 ] {ac65fc31-0c4e-4ba0-b2e0-cae7b10dc0be} executeQuery: Code: 42. DB::Exception: Function 'globalNotNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT globalNotNullInIgnoreSet(NULL, NULL, NULL);) 2025.04.02 01:50:20.023264 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:20.046263 [ 7799 ] {a766586c-de01-41cf-a8dd-5b99ad5a1006} executeQuery: Code: 42. DB::Exception: Function 'globalNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT globalNullIn(NULL, NULL, NULL);) 2025.04.02 01:50:20.050535 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:20.073111 [ 7799 ] {8c34582b-d8b8-42dc-9f8d-bcebd7cf7251} executeQuery: Code: 42. DB::Exception: Function 'globalNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT globalNullInIgnoreSet(NULL, NULL, NULL);) 2025.04.02 01:50:20.077246 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:20.107216 [ 7799 ] {0d7825c4-ccbd-431c-9cca-1b5dc533a34b} executeQuery: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 3, should be 1: In scope SELECT globalVariable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT globalVariable(NULL, NULL, NULL);) 2025.04.02 01:50:20.112618 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 3, should be 1: In scope SELECT globalVariable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:20.139557 [ 7799 ] {b5c71f95-624d-4a6e-898e-ed6bf6b1ef19} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 3, should be 4: In scope SELECT greatCircleAngle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT greatCircleAngle(NULL, NULL, NULL);) 2025.04.02 01:50:20.144633 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 3, should be 4: In scope SELECT greatCircleAngle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:20.172768 [ 7799 ] {02708e3a-3958-4005-8c61-aa40d208068f} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 3, should be 4: In scope SELECT greatCircleDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT greatCircleDistance(NULL, NULL, NULL);) 2025.04.02 01:50:20.177031 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 3, should be 4: In scope SELECT greatCircleDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:20.203861 [ 7799 ] {7d83dd24-4beb-407b-baa9-3909f72ac6ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function greater doesn't match: passed 3, should be 2: In scope SELECT greater(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT greater(NULL, NULL, NULL);) 2025.04.02 01:50:20.208343 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greater doesn't match: passed 3, should be 2: In scope SELECT greater(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:20.235838 [ 7799 ] {0ed96d6b-dc7c-47b3-bab3-df9ee08460b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 3, should be 2: In scope SELECT greaterOrEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT greaterOrEquals(NULL, NULL, NULL);) 2025.04.02 01:50:20.240141 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 3, should be 2: In scope SELECT greaterOrEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:20.495128 [ 6491 ] {ce0bc134-08ff-4bfa-96c2-92e4f3b3b374} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 0, should be 1: In scope SELECT base64URLEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45648) (comment: 03167_base64_url_functions.sql) (in query: -- incorrect number of arguments SELECT base64URLEncode();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029759d17 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000031bfebe2 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c013f7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 21. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 22. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 28. ? @ 0x00007f583d9b1ac3 29. ? @ 0x00007f583da43850 2025.04.02 01:50:20.500801 [ 6491 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 0, should be 1: In scope SELECT base64URLEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029759d17 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000031bfebe2 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c013f7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 21. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 22. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 28. ? @ 0x00007f583d9b1ac3 29. ? @ 0x00007f583da43850 2025.04.02 01:50:20.521085 [ 6491 ] {8849fde2-7ae9-4966-a2ff-0a93ddd52830} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 0, should be 1: In scope SELECT base64URLDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45648) (comment: 03167_base64_url_functions.sql) (in query: SELECT base64URLDecode();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029759d17 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000031bfebe2 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c013f7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 21. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 22. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 28. ? @ 0x00007f583d9b1ac3 29. ? @ 0x00007f583da43850 2025.04.02 01:50:20.525205 [ 6491 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 0, should be 1: In scope SELECT base64URLDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029759d17 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000031bfebe2 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c013f7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 21. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 22. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 28. ? @ 0x00007f583d9b1ac3 29. ? @ 0x00007f583da43850 2025.04.02 01:50:20.546632 [ 6491 ] {9474d932-e5ab-41bd-b99f-78fab594c4fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 0, should be 1: In scope SELECT tryBase64URLDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45648) (comment: 03167_base64_url_functions.sql) (in query: SELECT tryBase64URLDecode();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029759d17 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000031bfebe2 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c013f7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 21. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 22. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 28. ? @ 0x00007f583d9b1ac3 29. ? @ 0x00007f583da43850 2025.04.02 01:50:20.550320 [ 6491 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 0, should be 1: In scope SELECT tryBase64URLDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029759d17 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000031bfebe2 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c013f7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 21. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 22. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 28. ? @ 0x00007f583d9b1ac3 29. ? @ 0x00007f583da43850 2025.04.02 01:50:20.574560 [ 6491 ] {62f2c494-4e0f-400f-a9b7-bb99d3026f9b} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 2, should be 1: In scope SELECT base64URLEncode('foo', 'excess argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45648) (comment: 03167_base64_url_functions.sql) (in query: SELECT base64URLEncode('foo', 'excess argument');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029759d17 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000031bfebe2 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c013f7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 21. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 22. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 28. ? @ 0x00007f583d9b1ac3 29. ? @ 0x00007f583da43850 2025.04.02 01:50:20.578350 [ 6491 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 2, should be 1: In scope SELECT base64URLEncode('foo', 'excess argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029759d17 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000031bfebe2 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c013f7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 21. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 22. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 28. ? @ 0x00007f583d9b1ac3 29. ? @ 0x00007f583da43850 2025.04.02 01:50:20.595836 [ 6491 ] {14d16774-ac75-4ad1-ae4d-912b44a21e07} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 2, should be 1: In scope SELECT base64URLDecode('foo', 'excess argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45648) (comment: 03167_base64_url_functions.sql) (in query: SELECT base64URLDecode('foo', 'excess argument');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029759d17 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000031bfebe2 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c013f7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 21. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 22. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 28. ? @ 0x00007f583d9b1ac3 29. ? @ 0x00007f583da43850 2025.04.02 01:50:20.599074 [ 6491 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 2, should be 1: In scope SELECT base64URLDecode('foo', 'excess argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029759d17 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000031bfebe2 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c013f7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 21. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 22. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 28. ? @ 0x00007f583d9b1ac3 29. ? @ 0x00007f583da43850 2025.04.02 01:50:20.616961 [ 6491 ] {6776b937-441d-4ad9-a89c-66697a70c8bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 2, should be 1: In scope SELECT tryBase64URLDecode('foo', 'excess argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45648) (comment: 03167_base64_url_functions.sql) (in query: SELECT tryBase64URLDecode('foo', 'excess argument');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029759d17 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000031bfebe2 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c013f7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 21. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 22. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 28. ? @ 0x00007f583d9b1ac3 29. ? @ 0x00007f583da43850 2025.04.02 01:50:20.620455 [ 6491 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 2, should be 1: In scope SELECT tryBase64URLDecode('foo', 'excess argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029759d17 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000031bfebe2 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c013f7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 21. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 22. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 28. ? @ 0x00007f583d9b1ac3 29. ? @ 0x00007f583da43850 2025.04.02 01:50:20.964831 [ 6495 ] {99073c2e-266f-4096-b635-2badd5a1a291} executeQuery: Code: 507. DB::Exception: Sharding key is not deterministic. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45654) (comment: 01528_allow_nondeterministic_optimize_skip_unused_shards.sql) (in query: select * from dist_01528 where dummy = 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1548: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000003c8b7bb4 5. ./build_docker/./src/Storages/StorageDistributed.cpp:448: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003c8b2da1 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:914: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000386d0af9 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2035: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000386b5db5 8. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000003865cf3b 9. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 20. ? @ 0x00007f583d9b1ac3 21. ? @ 0x00007f583da43850 2025.04.02 01:50:20.969711 [ 6495 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key is not deterministic. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1548: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000003c8b7bb4 5. ./build_docker/./src/Storages/StorageDistributed.cpp:448: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003c8b2da1 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:914: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000386d0af9 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2035: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000386b5db5 8. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000003865cf3b 9. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 20. ? @ 0x00007f583d9b1ac3 21. ? @ 0x00007f583da43850 2025.04.02 01:50:21.370445 [ 7799 ] {2a0379ea-5995-48a9-ab31-f7bb4f7ef473} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaM2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3CellAreaM2(NULL, NULL, NULL);) 2025.04.02 01:50:21.375968 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaM2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:21.402657 [ 7799 ] {a8fa8af7-c1c6-42b5-9fd2-03d8487e7245} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaRads2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3CellAreaRads2(NULL, NULL, NULL);) 2025.04.02 01:50:21.407535 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaRads2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:21.435086 [ 7799 ] {e0dd58ce-39ba-4134-97ce-727b78b5b856} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3Distance doesn't match: passed 3, should be 2: In scope SELECT h3Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3Distance(NULL, NULL, NULL);) 2025.04.02 01:50:21.440341 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3Distance doesn't match: passed 3, should be 2: In scope SELECT h3Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:21.465119 [ 7799 ] {c5706249-ce60-4a1a-b121-6049344c74e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 3, should be 1: In scope SELECT h3EdgeAngle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3EdgeAngle(NULL, NULL, NULL);) 2025.04.02 01:50:21.469783 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 3, should be 1: In scope SELECT h3EdgeAngle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:21.493826 [ 7799 ] {edf3a50c-cbde-4a27-9940-17428e9825d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3EdgeLengthKm(NULL, NULL, NULL);) 2025.04.02 01:50:21.498355 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:21.524322 [ 7799 ] {352fd91a-7371-405d-af3b-2e3ce42016c8} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3EdgeLengthM(NULL, NULL, NULL);) 2025.04.02 01:50:21.528804 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:21.554746 [ 7799 ] {329ed597-8b3a-44e7-8468-9d5daf7ac2d6} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3ExactEdgeLengthKm(NULL, NULL, NULL);) 2025.04.02 01:50:21.559230 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:21.588951 [ 7799 ] {49a9ed4a-9133-4f21-b14a-323c7a3106fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3ExactEdgeLengthM(NULL, NULL, NULL);) 2025.04.02 01:50:21.593770 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:21.618739 [ 7799 ] {76347e4d-2d9b-4a2b-a077-53d32fdb0768} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthRads(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3ExactEdgeLengthRads(NULL, NULL, NULL);) 2025.04.02 01:50:21.623658 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthRads(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:21.651425 [ 7799 ] {1191934c-e38a-49f1-a3be-3a8c7852318a} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 3, should be 1: In scope SELECT h3GetBaseCell(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetBaseCell(NULL, NULL, NULL);) 2025.04.02 01:50:21.656067 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 3, should be 1: In scope SELECT h3GetBaseCell(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:21.682780 [ 3817 ] {25da5425-5708-4b00-bfaa-30cd2a1ba954} StorageBuffer (test_bdvda0rh.buffer_table1): Destination table test_bdvda0rh.merge_tree_table1 has different type of column s (LowCardinality(String) != String). Data from destination table are converted. 2025.04.02 01:50:21.682939 [ 7799 ] {33a39e13-2435-44fd-b852-21ed01020ef4} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetDestinationIndexFromUnidirectionalEdge(NULL, NULL, NULL);) 2025.04.02 01:50:21.687464 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:21.714339 [ 7799 ] {3a071fcf-7437-4917-ae7c-2f1386bd9ff6} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 3, should be 1: In scope SELECT h3GetFaces(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetFaces(NULL, NULL, NULL);) 2025.04.02 01:50:21.719401 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 3, should be 1: In scope SELECT h3GetFaces(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:21.746266 [ 7799 ] {f9bc8a01-d153-4362-b800-08fc8ba72946} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetIndexesFromUnidirectionalEdge(NULL, NULL, NULL);) 2025.04.02 01:50:21.750973 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:21.777524 [ 7799 ] {a4a5724d-ef01-47ce-bd9d-a71dc7c52bce} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetOriginIndexFromUnidirectionalEdge(NULL, NULL, NULL);) 2025.04.02 01:50:21.781906 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:21.808000 [ 7799 ] {b933c68a-11d7-497e-b9ec-0a4acdf5b0d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 3, should be 1: In scope SELECT h3GetPentagonIndexes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetPentagonIndexes(NULL, NULL, NULL);) 2025.04.02 01:50:21.812332 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 3, should be 1: In scope SELECT h3GetPentagonIndexes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:21.839122 [ 7799 ] {71eeac73-a963-43cb-b40f-f0795610e34f} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 3, should be 0: In scope SELECT h3GetRes0Indexes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetRes0Indexes(NULL, NULL, NULL);) 2025.04.02 01:50:21.843856 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 3, should be 0: In scope SELECT h3GetRes0Indexes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:21.873796 [ 7799 ] {1793cd0f-a3b1-4bc0-9cfd-7b592de6ac4e} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 3, should be 1: In scope SELECT h3GetResolution(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetResolution(NULL, NULL, NULL);) 2025.04.02 01:50:21.879118 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 3, should be 1: In scope SELECT h3GetResolution(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:21.892830 [ 6491 ] {54aea497-caf5-4976-8c6d-b0dd1511726c} executeQuery: Code: 117. DB::Exception: Failed to base64URLDecode input 'https://clickhouse.com': In scope SELECT base64URLDecode('https://clickhouse.com'). (INCORRECT_DATA) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45648) (comment: 03167_base64_url_functions.sql) (in query: -- test with invalid inputs SELECT base64URLDecode('https://clickhouse.com');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x000000000b24526d 4. DB::Base64Decode<(DB::Base64Variant)1>::perform(std::basic_string_view>, char8_t*) @ 0x000000000b24fdc7 5. DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x000000000b24f71f 6. DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b24e2be 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 29. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 30. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 2025.04.02 01:50:21.896688 [ 6491 ] {} TCPHandler: Code: 117. DB::Exception: Failed to base64URLDecode input 'https://clickhouse.com': In scope SELECT base64URLDecode('https://clickhouse.com'). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x000000000b24526d 4. DB::Base64Decode<(DB::Base64Variant)1>::perform(std::basic_string_view>, char8_t*) @ 0x000000000b24fdc7 5. DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x000000000b24f71f 6. DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b24e2be 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 29. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 30. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 2025.04.02 01:50:21.903417 [ 7799 ] {f922fc53-9a62-4601-a5f5-cd63eb82e8db} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdge doesn't match: passed 3, should be 2: In scope SELECT h3GetUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetUnidirectionalEdge(NULL, NULL, NULL);) 2025.04.02 01:50:21.907595 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdge doesn't match: passed 3, should be 2: In scope SELECT h3GetUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:21.931918 [ 7799 ] {9ef6c40b-7e25-42fa-ad99-585f20a698c0} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetUnidirectionalEdgeBoundary(NULL, NULL, NULL);) 2025.04.02 01:50:21.936342 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:21.950716 [ 6491 ] {263f821a-c5ac-40d7-9e28-c094c29b8552} executeQuery: Code: 117. DB::Exception: Failed to base64URLDecode input '12?': In scope SELECT base64URLDecode('12?'). (INCORRECT_DATA) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45648) (comment: 03167_base64_url_functions.sql) (in query: SELECT base64URLDecode('12?');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x000000000b24526d 4. DB::Base64Decode<(DB::Base64Variant)1>::perform(std::basic_string_view>, char8_t*) @ 0x000000000b24fdc7 5. DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x000000000b24f71f 6. DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b24e2be 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 29. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 30. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 2025.04.02 01:50:21.953993 [ 6491 ] {} TCPHandler: Code: 117. DB::Exception: Failed to base64URLDecode input '12?': In scope SELECT base64URLDecode('12?'). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x000000000b24526d 4. DB::Base64Decode<(DB::Base64Variant)1>::perform(std::basic_string_view>, char8_t*) @ 0x000000000b24fdc7 5. DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x000000000b24f71f 6. DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b24e2be 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 29. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 30. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 2025.04.02 01:50:21.963685 [ 7799 ] {f060a0db-cf40-4cd7-94fe-a58283fb61e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3GetUnidirectionalEdgesFromHexagon(NULL, NULL, NULL);) 2025.04.02 01:50:21.969582 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:21.981790 [ 3817 ] {e2d0f2b9-7610-416a-a892-71b911c67592} StorageBuffer (test_bdvda0rh.buffer_table1): Destination table test_bdvda0rh.merge_tree_table1 has different type of column s (LowCardinality(String) != String). Data from destination table are converted. 2025.04.02 01:50:21.993911 [ 7799 ] {6c94e524-e6c2-4bb0-ac14-0ee9b68063b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaKm2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3HexAreaKm2(NULL, NULL, NULL);) 2025.04.02 01:50:21.998437 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaKm2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:22.010497 [ 6491 ] {848d8a99-0675-4fee-9fa0-4c0b4d307570} executeQuery: Code: 117. DB::Exception: Failed to base64URLDecode input 'aHR0cHM6Ly9jbGlja': In scope SELECT base64URLDecode('aHR0cHM6Ly9jbGlja'). (INCORRECT_DATA) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45648) (comment: 03167_base64_url_functions.sql) (in query: SELECT base64URLDecode('aHR0cHM6Ly9jbGlja');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x000000000b24526d 4. DB::Base64Decode<(DB::Base64Variant)1>::perform(std::basic_string_view>, char8_t*) @ 0x000000000b24fdc7 5. DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x000000000b24f71f 6. DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b24e2be 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 29. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 30. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 2025.04.02 01:50:22.013830 [ 6491 ] {} TCPHandler: Code: 117. DB::Exception: Failed to base64URLDecode input 'aHR0cHM6Ly9jbGlja': In scope SELECT base64URLDecode('aHR0cHM6Ly9jbGlja'). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x000000000b24526d 4. DB::Base64Decode<(DB::Base64Variant)1>::perform(std::basic_string_view>, char8_t*) @ 0x000000000b24fdc7 5. DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x000000000b24f71f 6. DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b24e2be 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cafa2 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000031c06fdb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf53b1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf40b1 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf528f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bf739f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000031bfd164 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9fd3b 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 29. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 30. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 2025.04.02 01:50:22.025502 [ 7799 ] {8625babb-d3a8-4e70-b73a-6d6f0fa28f92} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaM2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3HexAreaM2(NULL, NULL, NULL);) 2025.04.02 01:50:22.029910 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaM2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:22.055540 [ 7799 ] {fb4adbfb-1948-48bc-8c36-e91acb14e96d} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexRing doesn't match: passed 3, should be 2: In scope SELECT h3HexRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3HexRing(NULL, NULL, NULL);) 2025.04.02 01:50:22.061574 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexRing doesn't match: passed 3, should be 2: In scope SELECT h3HexRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:22.066606 [ 3817 ] {52100b3d-3156-4106-8c28-bd00e6067835} StorageBuffer (test_bdvda0rh.buffer_table1): Destination table test_bdvda0rh.merge_tree_table1 has different type of column s (LowCardinality(String) != String). Data from destination table are converted. 2025.04.02 01:50:22.087991 [ 7799 ] {60782a78-a457-4bbc-82cc-5c45b3b97d37} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IndexesAreNeighbors doesn't match: passed 3, should be 2: In scope SELECT h3IndexesAreNeighbors(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3IndexesAreNeighbors(NULL, NULL, NULL);) 2025.04.02 01:50:22.093140 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IndexesAreNeighbors doesn't match: passed 3, should be 2: In scope SELECT h3IndexesAreNeighbors(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:22.120525 [ 7799 ] {e03db823-4b15-428e-a2a9-5b23004c68dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 3, should be 1: In scope SELECT h3IsPentagon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3IsPentagon(NULL, NULL, NULL);) 2025.04.02 01:50:22.125208 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 3, should be 1: In scope SELECT h3IsPentagon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:22.152260 [ 7799 ] {0b721823-e277-469c-80ae-4018a09717e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 3, should be 1: In scope SELECT h3IsResClassIII(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3IsResClassIII(NULL, NULL, NULL);) 2025.04.02 01:50:22.156886 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 3, should be 1: In scope SELECT h3IsResClassIII(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:22.182674 [ 7799 ] {826d65d8-1f3b-4420-bfb6-38f71008626a} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 3, should be 1: In scope SELECT h3IsValid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3IsValid(NULL, NULL, NULL);) 2025.04.02 01:50:22.187258 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 3, should be 1: In scope SELECT h3IsValid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:22.218202 [ 7799 ] {70682bd2-0605-410d-8a2e-3042b1ff2777} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3Line doesn't match: passed 3, should be 2: In scope SELECT h3Line(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3Line(NULL, NULL, NULL);) 2025.04.02 01:50:22.223828 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3Line doesn't match: passed 3, should be 2: In scope SELECT h3Line(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:22.248892 [ 7799 ] {14fcd2c6-d256-4b0a-a22f-7dd95b5c9f8f} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 3, should be 1: In scope SELECT h3NumHexagons(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3NumHexagons(NULL, NULL, NULL);) 2025.04.02 01:50:22.253594 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 3, should be 1: In scope SELECT h3NumHexagons(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:22.282416 [ 7799 ] {83798939-892b-4056-941d-e8a6428bd562} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 3, should be 4: In scope SELECT h3PointDistKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3PointDistKm(NULL, NULL, NULL);) 2025.04.02 01:50:22.287730 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 3, should be 4: In scope SELECT h3PointDistKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:22.313600 [ 7799 ] {51b6433c-05d1-42ef-ac29-ab0c2b417fdc} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 3, should be 4: In scope SELECT h3PointDistM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3PointDistM(NULL, NULL, NULL);) 2025.04.02 01:50:22.318578 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 3, should be 4: In scope SELECT h3PointDistM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:22.348855 [ 7799 ] {d16eb55a-2ed6-4eda-a403-a905b38e544b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 3, should be 4: In scope SELECT h3PointDistRads(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3PointDistRads(NULL, NULL, NULL);) 2025.04.02 01:50:22.354406 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 3, should be 4: In scope SELECT h3PointDistRads(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:22.384685 [ 7799 ] {efb58915-d73f-4928-a65c-a39e064f558b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToCenterChild doesn't match: passed 3, should be 2: In scope SELECT h3ToCenterChild(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3ToCenterChild(NULL, NULL, NULL);) 2025.04.02 01:50:22.389172 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToCenterChild doesn't match: passed 3, should be 2: In scope SELECT h3ToCenterChild(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:22.413013 [ 7799 ] {237a17a8-f225-4f31-894f-920548f3056e} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToChildren doesn't match: passed 3, should be 2: In scope SELECT h3ToChildren(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3ToChildren(NULL, NULL, NULL);) 2025.04.02 01:50:22.417948 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToChildren doesn't match: passed 3, should be 2: In scope SELECT h3ToChildren(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:22.440771 [ 7799 ] {b4c61b97-9a0d-49e3-b414-5f77bd700a83} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 3, should be 1: In scope SELECT h3ToGeo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3ToGeo(NULL, NULL, NULL);) 2025.04.02 01:50:22.445121 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 3, should be 1: In scope SELECT h3ToGeo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:22.468481 [ 7799 ] {c55ec143-fddc-476d-8591-661a24a45c40} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 3, should be 1: In scope SELECT h3ToGeoBoundary(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3ToGeoBoundary(NULL, NULL, NULL);) 2025.04.02 01:50:22.472977 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 3, should be 1: In scope SELECT h3ToGeoBoundary(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:22.499129 [ 7799 ] {f632ffa9-9fc4-4b0e-813d-2d1a30a73863} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToParent doesn't match: passed 3, should be 2: In scope SELECT h3ToParent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3ToParent(NULL, NULL, NULL);) 2025.04.02 01:50:22.503918 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToParent doesn't match: passed 3, should be 2: In scope SELECT h3ToParent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:22.529861 [ 7799 ] {53df2d30-8026-423c-95d4-0bfb642127db} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 3, should be 1: In scope SELECT h3ToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3ToString(NULL, NULL, NULL);) 2025.04.02 01:50:22.534438 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 3, should be 1: In scope SELECT h3ToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:22.559647 [ 7799 ] {bda9be32-2246-48ca-a6ea-73a9606486c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 3, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3UnidirectionalEdgeIsValid(NULL, NULL, NULL);) 2025.04.02 01:50:22.564256 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 3, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:22.591702 [ 7799 ] {aefedcbe-6ded-442f-8fd8-6df82bd52b4f} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3kRing doesn't match: passed 3, should be 2: In scope SELECT h3kRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT h3kRing(NULL, NULL, NULL);) 2025.04.02 01:50:22.596643 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3kRing doesn't match: passed 3, should be 2: In scope SELECT h3kRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:22.674190 [ 7799 ] {c5a8cc8e-4342-4352-bcbc-c7b097b7f401} executeQuery: Code: 42. DB::Exception: Number of arguments for function has doesn't match: passed 3, should be 2: In scope SELECT has(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT has(NULL, NULL, NULL);) 2025.04.02 01:50:22.679040 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function has doesn't match: passed 3, should be 2: In scope SELECT has(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:22.706910 [ 7799 ] {54d5dc70-c04e-4715-8ad0-ab1d968c91c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasAll doesn't match: passed 3, should be 2: In scope SELECT hasAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasAll(NULL, NULL, NULL);) 2025.04.02 01:50:22.711401 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasAll doesn't match: passed 3, should be 2: In scope SELECT hasAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:22.741581 [ 7799 ] {dd50fe01-b6c8-4acd-84a7-c0306c7c07e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasAny doesn't match: passed 3, should be 2: In scope SELECT hasAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasAny(NULL, NULL, NULL);) 2025.04.02 01:50:22.746517 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasAny doesn't match: passed 3, should be 2: In scope SELECT hasAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:22.817872 [ 7799 ] {435f5fb3-e311-4cac-9139-6a358d503e16} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequence doesn't match: passed 3, should be 2: In scope SELECT hasSubsequence(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasSubsequence(NULL, NULL, NULL);) 2025.04.02 01:50:22.822613 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequence doesn't match: passed 3, should be 2: In scope SELECT hasSubsequence(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:22.830923 [ 14197 ] {a46e232c-8266-4c16-8de5-a2b034503667} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `0b` in scope SELECT `0b`. (UNKNOWN_IDENTIFIER) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45716) (comment: 02493_inconsistent_hex_and_binary_number.expect) (in query: select 0b), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000035df38a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3750: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d4223f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 18. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 19. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 25. ? @ 0x00007f583d9b1ac3 26. ? @ 0x00007f583da43850 2025.04.02 01:50:22.836307 [ 14197 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `0b` in scope SELECT `0b`. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000035df38a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3750: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d4223f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 18. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 19. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 25. ? @ 0x00007f583d9b1ac3 26. ? @ 0x00007f583da43850 2025.04.02 01:50:22.847263 [ 7799 ] {81dc4c83-5966-42bf-a8d9-f4d13a93ea59} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasSubsequenceCaseInsensitive(NULL, NULL, NULL);) 2025.04.02 01:50:22.852346 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:22.877307 [ 7799 ] {d8f2e065-a095-4bbf-abb9-5050dcca36bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasSubsequenceCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.04.02 01:50:22.882149 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:22.906804 [ 7799 ] {10d216d9-47e4-4809-9e1b-83261a1c4c62} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasSubsequenceUTF8(NULL, NULL, NULL);) 2025.04.02 01:50:22.911703 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:22.937931 [ 7799 ] {b6ed3171-e42e-474e-8f08-9995aa15950e} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubstr doesn't match: passed 3, should be 2: In scope SELECT hasSubstr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasSubstr(NULL, NULL, NULL);) 2025.04.02 01:50:22.943151 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubstr doesn't match: passed 3, should be 2: In scope SELECT hasSubstr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:22.969082 [ 7799 ] {da49f28f-20b2-4000-977e-fe9b50627c5e} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 3, should be 0: In scope SELECT hasThreadFuzzer(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasThreadFuzzer(NULL, NULL, NULL);) 2025.04.02 01:50:22.973635 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 3, should be 0: In scope SELECT hasThreadFuzzer(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:22.999113 [ 7799 ] {bb658e40-2f68-4d6b-8384-a5ea71d15591} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasToken doesn't match: passed 3, should be 2: In scope SELECT hasToken(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasToken(NULL, NULL, NULL);) 2025.04.02 01:50:23.003874 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasToken doesn't match: passed 3, should be 2: In scope SELECT hasToken(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:23.029567 [ 7799 ] {976ac013-afc6-4aee-86ae-26ef36f87187} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasTokenCaseInsensitive(NULL, NULL, NULL);) 2025.04.02 01:50:23.034545 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:23.061916 [ 7799 ] {00b08750-b86f-453b-bcd1-3adb71dd4cfa} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitiveOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitiveOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasTokenCaseInsensitiveOrNull(NULL, NULL, NULL);) 2025.04.02 01:50:23.066733 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitiveOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitiveOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:23.091768 [ 7799 ] {92c5ccda-e1ee-4703-9b58-bae687035e3c} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hasTokenOrNull(NULL, NULL, NULL);) 2025.04.02 01:50:23.096396 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:23.120888 [ 7799 ] {2a69468c-5f08-4937-aea6-1c24acc0dc75} executeQuery: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 3, should be 1: In scope SELECT hex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hex(NULL, NULL, NULL);) 2025.04.02 01:50:23.125598 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 3, should be 1: In scope SELECT hex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:23.149291 [ 7799 ] {655dc070-02e1-454e-ac49-341a50bfcfd4} executeQuery: Code: 42. DB::Exception: Number of arguments for function hilbertDecode doesn't match: passed 3, should be 2: In scope SELECT hilbertDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hilbertDecode(NULL, NULL, NULL);) 2025.04.02 01:50:23.153793 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hilbertDecode doesn't match: passed 3, should be 2: In scope SELECT hilbertDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:23.457654 [ 7799 ] {c5386c4a-9751-4e0f-8b28-7a5b946eac82} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hostName(NULL, NULL, NULL);) 2025.04.02 01:50:23.465029 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:23.493202 [ 7799 ] {40edd6f5-cdbb-4739-a0a6-032085531434} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostname(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hostname(NULL, NULL, NULL);) 2025.04.02 01:50:23.499411 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostname(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:23.524152 [ 7799 ] {db939343-226f-4d34-80c2-f85aafda6352} executeQuery: Code: 42. DB::Exception: Number of arguments for function hypot doesn't match: passed 3, should be 2: In scope SELECT hypot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT hypot(NULL, NULL, NULL);) 2025.04.02 01:50:23.529623 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hypot doesn't match: passed 3, should be 2: In scope SELECT hypot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:23.554990 [ 7799 ] {ebbc54d2-a031-471f-8782-dca8b5a17e5f} executeQuery: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 3, should be 1: In scope SELECT identity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT identity(NULL, NULL, NULL);) 2025.04.02 01:50:23.561030 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 3, should be 1: In scope SELECT identity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:23.585279 [ 7799 ] {66e02280-e469-462a-9bb9-c3f88435a7fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 3, should be 1: In scope SELECT idnaDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT idnaDecode(NULL, NULL, NULL);) 2025.04.02 01:50:23.590504 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 3, should be 1: In scope SELECT idnaDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:23.616220 [ 7799 ] {9ff7b7e5-644d-4dc4-9525-a47195911ecd} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 3, should be 1: In scope SELECT idnaEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT idnaEncode(NULL, NULL, NULL);) 2025.04.02 01:50:23.621357 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 3, should be 1: In scope SELECT idnaEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:23.693414 [ 7799 ] {d51b8804-d500-4aba-852d-14643c83528a} executeQuery: Code: 42. DB::Exception: Number of arguments for function ifNotFinite doesn't match: passed 3, should be 2: In scope SELECT ifNotFinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ifNotFinite(NULL, NULL, NULL);) 2025.04.02 01:50:23.702105 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ifNotFinite doesn't match: passed 3, should be 2: In scope SELECT ifNotFinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:23.722670 [ 7799 ] {7d818fe8-312c-435a-9319-cd5a573b2864} executeQuery: Code: 42. DB::Exception: Number of arguments for function ifNull doesn't match: passed 3, should be 2: In scope SELECT ifNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ifNull(NULL, NULL, NULL);) 2025.04.02 01:50:23.729091 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ifNull doesn't match: passed 3, should be 2: In scope SELECT ifNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:23.776280 [ 2377 ] {3978d005-2e50-4916-ae51-f7e0908b4e81} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `0b` in scope SELECT `0b`. (UNKNOWN_IDENTIFIER) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45750) (comment: 02493_inconsistent_hex_and_binary_number.expect) (in query: select 0b;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000035df38a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3750: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d4223f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 18. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 19. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 25. ? @ 0x00007f583d9b1ac3 26. ? @ 0x00007f583da43850 2025.04.02 01:50:23.781185 [ 2377 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `0b` in scope SELECT `0b`. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000035df38a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3750: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d4223f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 18. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 19. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 25. ? @ 0x00007f583d9b1ac3 26. ? @ 0x00007f583da43850 2025.04.02 01:50:23.804251 [ 7799 ] {28f62401-2d7b-41cf-9f7d-7f247a065f89} executeQuery: Code: 42. DB::Exception: Number of arguments for function ilike doesn't match: passed 3, should be 2: In scope SELECT ilike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ilike(NULL, NULL, NULL);) 2025.04.02 01:50:23.808707 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ilike doesn't match: passed 3, should be 2: In scope SELECT ilike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:23.833634 [ 7799 ] {21b89f3d-09a5-4227-86cd-8011e728e802} executeQuery: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT in(NULL, NULL, NULL);) 2025.04.02 01:50:23.838951 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:23.863664 [ 7799 ] {f743f206-70dc-4f59-8945-610faad9a6a7} executeQuery: Code: 42. DB::Exception: Function 'inIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT inIgnoreSet(NULL, NULL, NULL);) 2025.04.02 01:50:23.868447 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Function 'inIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:23.941662 [ 7799 ] {6a26cf62-024f-4d4b-9098-874d9cff5c7c} executeQuery: Code: 42. DB::Exception: Number of arguments for function indexOf doesn't match: passed 3, should be 2: In scope SELECT indexOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT indexOf(NULL, NULL, NULL);) 2025.04.02 01:50:23.945972 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function indexOf doesn't match: passed 3, should be 2: In scope SELECT indexOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:23.971989 [ 7799 ] {d0d7d0bc-bf05-4769-ad10-48295710f1ee} executeQuery: Code: 42. DB::Exception: Number of arguments for function indexOfAssumeSorted doesn't match: passed 3, should be 2: In scope SELECT indexOfAssumeSorted(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT indexOfAssumeSorted(NULL, NULL, NULL);) 2025.04.02 01:50:23.976664 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function indexOfAssumeSorted doesn't match: passed 3, should be 2: In scope SELECT indexOfAssumeSorted(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:24.004105 [ 7799 ] {0c366bbc-5b99-49de-b5ac-cd55d0db889e} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 3, should be 1: In scope SELECT initcap(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT initcap(NULL, NULL, NULL);) 2025.04.02 01:50:24.009724 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 3, should be 1: In scope SELECT initcap(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:24.036203 [ 7799 ] {9733bf63-fe4c-4db0-9b3c-6d0e2512736a} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 3, should be 1: In scope SELECT initcapUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT initcapUTF8(NULL, NULL, NULL);) 2025.04.02 01:50:24.040893 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 3, should be 1: In scope SELECT initcapUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:24.049586 [ 8029 ] {d6c6d169-51f1-4591-8824-73ab14557759} ConnectionPoolWithFailover: Connection failed at try â„–1, reason: Code: 210. DB::NetException: Connection refused (127.0.0.3:1234). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:50:24.050207 [ 8029 ] {d6c6d169-51f1-4591-8824-73ab14557759} ConnectionPoolWithFailover: Connection failed at try â„–2, reason: Code: 210. DB::NetException: Connection refused (127.0.0.3:1234). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:50:24.050576 [ 8029 ] {d6c6d169-51f1-4591-8824-73ab14557759} ConnectionPoolWithFailover: Connection failed at try â„–3, reason: Code: 210. DB::NetException: Connection refused (127.0.0.3:1234). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:50:24.053562 [ 8030 ] {d6c6d169-51f1-4591-8824-73ab14557759} ConnectionPoolWithFailover: There is no table `test_12ids2lr`.`local_01099_b` on server: 127.0.0.1:9000 2025.04.02 01:50:24.068893 [ 8027 ] {d6c6d169-51f1-4591-8824-73ab14557759} ConnectionPoolWithFailover: There is no table `test_12ids2lr`.`local_01099_b` on server: 127.0.0.2:9000 2025.04.02 01:50:24.068991 [ 7799 ] {9cd0b1a2-dd73-4843-8d5f-08f7ee6ba8f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initialQueryID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT initialQueryID(NULL, NULL, NULL);) 2025.04.02 01:50:24.073451 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initialQueryID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:24.097133 [ 7799 ] {bcbcde35-3ea4-41a2-8a0f-083e5bcf00e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initial_query_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT initial_query_id(NULL, NULL, NULL);) 2025.04.02 01:50:24.101527 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initial_query_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:24.128685 [ 7799 ] {27831470-e3e8-4795-9205-bee66f7061d2} executeQuery: Code: 43. DB::Exception: First argument for function initializeAggregation must be constant string: name of aggregate function.: In scope SELECT initializeAggregation(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT initializeAggregation(NULL, NULL, NULL);) 2025.04.02 01:50:24.133287 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function initializeAggregation must be constant string: name of aggregate function.: In scope SELECT initializeAggregation(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:24.144489 [ 4457 ] {3e9e7da8-5326-4c19-b4a1-85c7a4dd862c} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9010 -> [::1]:45562). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45562) (in query: SELECT 'Hello, world'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000020b76be5 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000020b7aee3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003f05f2aa 5. DB::WriteBuffer::next() @ 0x00000000088f6ec1 6. ./build_docker/./src/Server/TCPHandler.cpp:2544: DB::TCPHandler::runImpl() @ 0x000000003f42c5dc 7. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 13. ? @ 0x00007f583d9b1ac3 14. ? @ 0x00007f583da43850 2025.04.02 01:50:24.147554 [ 4457 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9010 -> [::1]:45562). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000020b76be5 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000020b7aee3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003f05f2aa 5. DB::WriteBuffer::next() @ 0x00000000088f6ec1 6. ./build_docker/./src/Server/TCPHandler.cpp:2544: DB::TCPHandler::runImpl() @ 0x000000003f42c5dc 7. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 13. ? @ 0x00007f583d9b1ac3 14. ? @ 0x00007f583da43850 2025.04.02 01:50:24.207361 [ 7799 ] {3a247c82-b156-49a7-9dbf-05b6aed47a87} executeQuery: Code: 42. DB::Exception: Number of arguments for function intDiv doesn't match: passed 3, should be 2: In scope SELECT intDiv(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT intDiv(NULL, NULL, NULL);) 2025.04.02 01:50:24.212603 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intDiv doesn't match: passed 3, should be 2: In scope SELECT intDiv(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:24.243853 [ 7799 ] {2ba65098-4e31-4eec-b368-510d7aaf8c1e} executeQuery: Code: 42. DB::Exception: Number of arguments for function intDivOrZero doesn't match: passed 3, should be 2: In scope SELECT intDivOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT intDivOrZero(NULL, NULL, NULL);) 2025.04.02 01:50:24.249794 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intDivOrZero doesn't match: passed 3, should be 2: In scope SELECT intDivOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:24.275104 [ 7799 ] {c89c287f-7898-4f24-880e-3d3c5d2f8b49} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 3, should be 1: In scope SELECT intExp10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT intExp10(NULL, NULL, NULL);) 2025.04.02 01:50:24.279681 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 3, should be 1: In scope SELECT intExp10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:24.308867 [ 7799 ] {ad7779bb-0b9b-45eb-a62a-69a51a91a5f5} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 3, should be 1: In scope SELECT intExp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT intExp2(NULL, NULL, NULL);) 2025.04.02 01:50:24.315664 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 3, should be 1: In scope SELECT intExp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:24.340729 [ 7799 ] {682fadf2-e589-4eef-b7d3-094ad3c3ab69} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 3, should be 1: In scope SELECT intHash32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT intHash32(NULL, NULL, NULL);) 2025.04.02 01:50:24.346969 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 3, should be 1: In scope SELECT intHash32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:24.371348 [ 7799 ] {7acc0363-46b1-452f-bd73-ef8b8ee53cc0} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 3, should be 1: In scope SELECT intHash64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT intHash64(NULL, NULL, NULL);) 2025.04.02 01:50:24.376459 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 3, should be 1: In scope SELECT intHash64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:24.444360 [ 14205 ] {3da9fd55-2350-4fd4-860e-2a7fb68d15a4} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9010 -> [::1]:45570). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45570) (in query: SELECT 'Hello, world'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000020b76be5 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000020b7b476 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003f05f2aa 5. DB::WriteBuffer::next() @ 0x00000000088f6ec1 6. ./build_docker/./src/Server/TCPHandler.cpp:2564: DB::TCPHandler::sendProgress(DB::QueryState&) @ 0x000000003f452774 7. ./build_docker/./src/Server/TCPHandler.cpp:1287: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003f451bf3 8. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000003f42c464 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:50:24.444375 [ 3161 ] {3e6d93c1-b9fa-472c-b558-dd89f2f3aa58} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9010 -> [::1]:45556). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45556) (in query: SELECT 'Hello, world'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000020b76be5 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000020b7b476 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003f05f2aa 5. DB::WriteBuffer::next() @ 0x00000000088f6ec1 6. ./build_docker/./src/Server/TCPHandler.cpp:2564: DB::TCPHandler::sendProgress(DB::QueryState&) @ 0x000000003f452774 7. ./build_docker/./src/Server/TCPHandler.cpp:1287: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003f451bf3 8. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000003f42c464 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:50:24.449869 [ 14205 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9010 -> [::1]:45570). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000020b76be5 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000020b7b476 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003f05f2aa 5. DB::WriteBuffer::next() @ 0x00000000088f6ec1 6. ./build_docker/./src/Server/TCPHandler.cpp:2564: DB::TCPHandler::sendProgress(DB::QueryState&) @ 0x000000003f452774 7. ./build_docker/./src/Server/TCPHandler.cpp:1287: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003f451bf3 8. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000003f42c464 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:50:24.450924 [ 3161 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9010 -> [::1]:45556). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000020b76be5 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000020b7b476 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003f05f2aa 5. DB::WriteBuffer::next() @ 0x00000000088f6ec1 6. ./build_docker/./src/Server/TCPHandler.cpp:2564: DB::TCPHandler::sendProgress(DB::QueryState&) @ 0x000000003f452774 7. ./build_docker/./src/Server/TCPHandler.cpp:1287: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003f451bf3 8. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000003f42c464 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:50:24.459668 [ 7799 ] {e754a355-2f14-4edb-853c-84ad07c66b92} executeQuery: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 3, should be 1: In scope SELECT isConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isConstant(NULL, NULL, NULL);) 2025.04.02 01:50:24.464247 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 3, should be 1: In scope SELECT isConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:24.494529 [ 1424 ] {d6c6d169-51f1-4591-8824-73ab14557759} StorageDistributed (distributed_01099_b): Cannot flush: Code: 279. DB::NetException: All connection tries failed. Log: There is no table `test_12ids2lr`.`local_01099_b` on server: 127.0.0.2:9000 : While sending /var/lib/clickhouse/store/661/6617bd54-5e18-4adc-9b99-c38c7d2e7add/shard1_replica2/2.bin. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000003d3f8396 3. ./src/Common/PoolWithFailoverBase.h:320: PoolWithFailoverBase::getMany(unsigned long, unsigned long, unsigned long, unsigned long, bool, bool, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::function const&) @ 0x000000003f0974a6 4. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:236: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x000000003f08eb0a 5. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:180: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x000000003f08fb40 6. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:433: DB::DistributedAsyncInsertDirectoryQueue::processFile(String&, DB::SettingsChanges const&) @ 0x000000003d98e7d7 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:395: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x000000003d97eaab 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:172: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x000000003d97e2ea 9. ./build_docker/./src/Storages/StorageDistributed.cpp:1754: void std::__function::__policy_invoker::__call_impl, DB::SettingsChanges const&, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003c9095ce 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000027a374ac 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000027a3728d 12. ./contrib/llvm-project/libcxx/include/future:1876: std::packaged_task::operator()() @ 0x0000000027a39b9d 13. ./src/Common/threadPoolCallbackRunner.h:167: void std::__function::__policy_invoker::__call_impl>, std::function>::operator()(std::function&&, Priority)::'lambda0'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000027a39a0e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002097cef4 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002098fd26 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000002098fadf 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 19. ? @ 0x00007f583d9b1ac3 20. ? @ 0x00007f583da43850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 01:50:24.531882 [ 7799 ] {467e7738-f001-43bd-a789-91f4265662cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 3, should be 1: In scope SELECT isDynamicElementInSharedData(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isDynamicElementInSharedData(NULL, NULL, NULL);) 2025.04.02 01:50:24.536155 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 3, should be 1: In scope SELECT isDynamicElementInSharedData(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:24.562373 [ 7799 ] {e758563d-dfd8-46c2-a3b4-cb55fa4e3c44} executeQuery: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 3, should be 1: In scope SELECT isFinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isFinite(NULL, NULL, NULL);) 2025.04.02 01:50:24.568171 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 3, should be 1: In scope SELECT isFinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:24.592321 [ 7799 ] {23641148-ed71-405e-a6b8-16f667dc2c9f} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPAddressInRange doesn't match: passed 3, should be 2: In scope SELECT isIPAddressInRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isIPAddressInRange(NULL, NULL, NULL);) 2025.04.02 01:50:24.596969 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPAddressInRange doesn't match: passed 3, should be 2: In scope SELECT isIPAddressInRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:24.624650 [ 7799 ] {9da26ab5-58bb-4b67-9b87-a17c4584e94b} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 3, should be 1: In scope SELECT isIPv4String(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isIPv4String(NULL, NULL, NULL);) 2025.04.02 01:50:24.631372 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 3, should be 1: In scope SELECT isIPv4String(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:24.659363 [ 7799 ] {6dbc6dfb-d09f-483b-b5e9-fb6b228d3df2} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 3, should be 1: In scope SELECT isIPv6String(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isIPv6String(NULL, NULL, NULL);) 2025.04.02 01:50:24.664029 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 3, should be 1: In scope SELECT isIPv6String(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:24.692177 [ 7799 ] {786c6c6e-2f1e-40ed-a483-7ee2a0532b3b} executeQuery: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 3, should be 1: In scope SELECT isInfinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isInfinite(NULL, NULL, NULL);) 2025.04.02 01:50:24.697008 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 3, should be 1: In scope SELECT isInfinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:24.721854 [ 7799 ] {15b816d6-b06a-45e4-8b67-add9aaed9b66} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 3, should be 1: In scope SELECT isNaN(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isNaN(NULL, NULL, NULL);) 2025.04.02 01:50:24.726524 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 3, should be 1: In scope SELECT isNaN(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:24.736789 [ 3300 ] {f0cda53e-9fb3-4016-ad62-f09cbf6fcc8e} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `0b` in scope SELECT `0b`. (UNKNOWN_IDENTIFIER) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45762) (comment: 02493_inconsistent_hex_and_binary_number.expect) (in query: select 0b ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000035df38a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3750: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d4223f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 18. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 19. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 25. ? @ 0x00007f583d9b1ac3 26. ? @ 0x00007f583da43850 2025.04.02 01:50:24.742714 [ 3300 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `0b` in scope SELECT `0b`. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000035df38a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3750: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d4223f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 18. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 19. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 25. ? @ 0x00007f583d9b1ac3 26. ? @ 0x00007f583da43850 2025.04.02 01:50:24.751852 [ 7799 ] {eac3607b-d0f1-476f-b533-1b47d97489aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 3, should be 2: In scope SELECT isNotDistinctFrom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isNotDistinctFrom(NULL, NULL, NULL);) 2025.04.02 01:50:24.756684 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 3, should be 2: In scope SELECT isNotDistinctFrom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:24.784418 [ 7799 ] {c213fa5d-bde6-454b-98a1-ace5d337a320} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 3, should be 1: In scope SELECT isNotNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isNotNull(NULL, NULL, NULL);) 2025.04.02 01:50:24.789296 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 3, should be 1: In scope SELECT isNotNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:24.819041 [ 7799 ] {af2d9303-d29f-461b-b62a-6083241a72c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 3, should be 1: In scope SELECT isNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isNull(NULL, NULL, NULL);) 2025.04.02 01:50:24.821392 [ 3807 ] {b42a54ac-c0bd-4583-8ece-f9ba78ba1905} : Logical error: 'Replica info is not initialized'. 2025.04.02 01:50:24.821479 [ 14150 ] {55cd92e2-7228-4a66-b229-6f6401b2edda} executeQuery: Code: 128. DB::Exception: Suspiciously many rows in Native format: 2178749300044435230: While executing Native. (TOO_LARGE_ARRAY_SIZE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45756) (comment: 02687_native_fuzz.sql) (in query: -- It correctly throws exception about incorrect data instead of a low-level exception about the allocator: SELECT * FROM format(Native, 'WatchID Int64, JavaEnable Int16, UTMCaTitle String, GoodEvent Int16, EventTime DateTime, EventDate Date, Countem String, FromTag String, HasGCLID Int16, RefererHash Int64, URLHash Int64, CLID Int16', $$ žžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžžž‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûURLHashInt64Í|3úÐb.‹Í|3úÐb.‹Í|3úÐb.‹Í|3úÐb.‹Ž oâïòeý€ à#â\X-h³ýX vÀvÍÀ‰Çh˜´9›DÍ|3úÐb.‹CLIDInt32ä$$);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000009f9b88a 4. ./build_docker/./src/Formats/NativeReader.cpp:142: DB::NativeReader::read() @ 0x000000003f6103a8 5. ./build_docker/./src/Processors/Formats/Impl/NativeFormat.cpp:44: DB::NativeInputFormat::read() @ 0x000000003fbc70f7 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003f777319 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003f6e9178 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003f6e8571 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762e32 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 14. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000274bc9f5 15. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000032dd63f1 16. ./build_docker/./src/Interpreters/Context.cpp:2365: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000036542f3f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4956: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000035d4d991 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5295: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000035ddf701 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5552: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24c93 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 30. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 31. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 2025.04.02 01:50:24.825021 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 3, should be 1: In scope SELECT isNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:24.826638 [ 14150 ] {} TCPHandler: Code: 128. DB::Exception: Suspiciously many rows in Native format: 2178749300044435230: While executing Native. (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000009f9b88a 4. ./build_docker/./src/Formats/NativeReader.cpp:142: DB::NativeReader::read() @ 0x000000003f6103a8 5. ./build_docker/./src/Processors/Formats/Impl/NativeFormat.cpp:44: DB::NativeInputFormat::read() @ 0x000000003fbc70f7 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003f777319 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003f6e9178 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003f6e8571 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003f71d736 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003f762e32 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003f763724 14. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000274bc9f5 15. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000032dd63f1 16. ./build_docker/./src/Interpreters/Context.cpp:2365: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000036542f3f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4956: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000035d4d991 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5295: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000035ddf701 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5552: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24c93 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 30. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 31. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 2025.04.02 01:50:24.854232 [ 7799 ] {ab1c32e3-8051-459f-912c-e1e32642cf5c} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 3, should be 1: In scope SELECT isNullable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isNullable(NULL, NULL, NULL);) 2025.04.02 01:50:24.859757 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 3, should be 1: In scope SELECT isNullable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:24.888375 [ 7799 ] {7fc06549-0ba1-48d4-927d-285e25239e25} executeQuery: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isValidJSON(NULL, NULL, NULL);) 2025.04.02 01:50:24.893717 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:24.922829 [ 7799 ] {c9abdaf7-37cf-4918-a798-f61e0ff02568} executeQuery: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT isValidUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isValidUTF8(NULL, NULL, NULL);) 2025.04.02 01:50:24.928662 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT isValidUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:24.952877 [ 7799 ] {00bd724b-e2dd-4cb0-b6db-af6dd473775e} executeQuery: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 3, should be 1: In scope SELECT isZeroOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT isZeroOrNull(NULL, NULL, NULL);) 2025.04.02 01:50:24.957135 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 3, should be 1: In scope SELECT isZeroOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:24.983443 [ 7799 ] {02d16578-bc9e-4b58-a990-be71daacdd7f} executeQuery: Code: 42. DB::Exception: Number of arguments for function jaroSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroSimilarity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT jaroSimilarity(NULL, NULL, NULL);) 2025.04.02 01:50:24.988134 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jaroSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroSimilarity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:25.014601 [ 7799 ] {82fb6364-b6b8-4233-a3db-7b799bf897d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function jaroWinklerSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroWinklerSimilarity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT jaroWinklerSimilarity(NULL, NULL, NULL);) 2025.04.02 01:50:25.018901 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jaroWinklerSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroWinklerSimilarity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:25.126027 [ 7799 ] {99ecfb5d-79c7-4a8e-a5bb-5ab88a9affd5} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function joinGet, expected a const string.: In scope SELECT joinGet(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT joinGet(NULL, NULL, NULL);) 2025.04.02 01:50:25.130088 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function joinGet, expected a const string.: In scope SELECT joinGet(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:25.154136 [ 7799 ] {b337df85-191c-4b89-8ee6-3beeefc8e31b} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function joinGet, expected a const string.: In scope SELECT joinGetOrNull(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT joinGetOrNull(NULL, NULL, NULL);) 2025.04.02 01:50:25.158195 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function joinGet, expected a const string.: In scope SELECT joinGetOrNull(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:25.186716 [ 3807 ] {b42a54ac-c0bd-4583-8ece-f9ba78ba1905} : Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 4. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:727: DB::RemoteQueryExecutor::processReadTaskRequest() @ 0x0000000034b283cd 5. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:623: DB::RemoteQueryExecutor::processPacket(DB::Packet) @ 0x0000000034b21488 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:562: DB::RemoteQueryExecutor::readAsync() @ 0x0000000034b25dc3 7. ./build_docker/./src/Processors/Sources/RemoteSource.cpp:182: DB::RemoteSource::tryGenerate() @ 0x0000000040415925 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003f6e8571 9. ./build_docker/./src/Processors/Sources/RemoteSource.cpp:134: DB::RemoteSource::work() @ 0x0000000040414fb0 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003f71c8c3 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c2f5 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:49: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003f719de5 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000209762ca 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000020988a64 17. ? @ 0x00007f583d9b1ac3 18. ? @ 0x00007f583da43850 2025.04.02 01:50:25.188689 [ 17965 ] {} BaseDaemon: ########## Short fault info ############ 2025.04.02 01:50:25.189266 [ 17965 ] {} BaseDaemon: (version 24.12.2.20221.altinityantalya (altinity build), build id: E3EBE392F6E30F869D3C8A7C787AA68127B123A4, git hash: 82252d159dc02cab0f366aaa5691adc1545dd11d, architecture: x86_64) (from thread 3807) Received signal 6 2025.04.02 01:50:25.189724 [ 17965 ] {} BaseDaemon: Signal description: Aborted 2025.04.02 01:50:25.190011 [ 17965 ] {} BaseDaemon: 2025.04.02 01:50:25.190317 [ 17965 ] {} BaseDaemon: Stack trace: 0x00005636c1d40a5e 0x00005636c273c1b7 0x00005636a9e66bae 0x00007f583d95f520 0x00007f583d9b39fd 0x00007f583d95f476 0x00007f583d9457f3 0x00005636c1c9248b 0x00005636c1c93e61 0x00005636a9e8e1d5 0x00005636a9eb5804 0x00005636d60e93cd 0x00005636d60e2488 0x00005636d60e6dc3 0x00005636e19d6925 0x00005636e0ca9571 0x00005636e19d5fb0 0x00005636e0d148b1 0x00005636e0cdfb14 0x00005636e0cdd8c3 0x00005636e0cdd2f5 0x00005636e0cdade5 0x00005636c1f372ca 0x00005636c1f49a64 0x00007f583d9b1ac3 0x00007f583da43850 2025.04.02 01:50:25.190646 [ 17965 ] {} BaseDaemon: ######################################## 2025.04.02 01:50:25.191602 [ 17965 ] {} BaseDaemon: (version 24.12.2.20221.altinityantalya (altinity build), build id: E3EBE392F6E30F869D3C8A7C787AA68127B123A4, git hash: 82252d159dc02cab0f366aaa5691adc1545dd11d) (from thread 3807) (query_id: b42a54ac-c0bd-4583-8ece-f9ba78ba1905) (query: INSERT INTO distributed_01099_b SELECT * FROM urlCluster('test_cluster_two_shards', 'http://localhost:8123/?query=select+{1,2,3}+format+TSV', 'TSV', 's String');) Received signal Aborted (6) 2025.04.02 01:50:25.192305 [ 17965 ] {} BaseDaemon: 2025.04.02 01:50:25.192747 [ 17965 ] {} BaseDaemon: Stack trace: 0x00005636c1d40a5e 0x00005636c273c1b7 0x00005636a9e66bae 0x00007f583d95f520 0x00007f583d9b39fd 0x00007f583d95f476 0x00007f583d9457f3 0x00005636c1c9248b 0x00005636c1c93e61 0x00005636a9e8e1d5 0x00005636a9eb5804 0x00005636d60e93cd 0x00005636d60e2488 0x00005636d60e6dc3 0x00005636e19d6925 0x00005636e0ca9571 0x00005636e19d5fb0 0x00005636e0d148b1 0x00005636e0cdfb14 0x00005636e0cdd8c3 0x00005636e0cdd2f5 0x00005636e0cdade5 0x00005636c1f372ca 0x00005636c1f49a64 0x00007f583d9b1ac3 0x00007f583da43850 2025.04.02 01:50:25.224941 [ 7799 ] {caa3a2c7-5d63-46bd-b9a7-ae56be537f67} executeQuery: Code: 42. DB::Exception: Number of arguments for function jumpConsistentHash doesn't match: passed 3, should be 2: In scope SELECT jumpConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT jumpConsistentHash(NULL, NULL, NULL);) 2025.04.02 01:50:25.229733 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jumpConsistentHash doesn't match: passed 3, should be 2: In scope SELECT jumpConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:25.338711 [ 7799 ] {49feb188-738d-4e52-84ed-b9e1d4418924} executeQuery: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT kostikConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT kostikConsistentHash(NULL, NULL, NULL);) 2025.04.02 01:50:25.342918 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT kostikConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:25.492846 [ 17965 ] {} BaseDaemon: 0.0. inlined from ./build_docker/./src/Common/StackTrace.cpp:381: StackTrace::tryCapture() 2025.04.02 01:50:25.493440 [ 17965 ] {} BaseDaemon: 0. ./build_docker/./src/Common/StackTrace.cpp:350: StackTrace::StackTrace(ucontext_t const&) @ 0x000000002077fa5e 2025.04.02 01:50:25.552722 [ 7799 ] {0ea08a7e-6bfc-462e-8c6d-efc8edd03ac5} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lagInFrame(NULL, NULL, NULL);) 2025.04.02 01:50:25.557251 [ 7799 ] {} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.04.02 01:50:25.583330 [ 6485 ] {29700f17-0ff1-4993-b91a-fc73b0a11ac8} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `0x` in scope SELECT `0x`. (UNKNOWN_IDENTIFIER) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45796) (comment: 02493_inconsistent_hex_and_binary_number.expect) (in query: select 0x), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000035df38a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3750: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d4223f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 18. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 19. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 25. ? @ 0x00007f583d9b1ac3 26. ? @ 0x00007f583da43850 2025.04.02 01:50:25.588420 [ 6485 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `0x` in scope SELECT `0x`. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000035df38a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3750: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d4223f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 18. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 19. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 25. ? @ 0x00007f583d9b1ac3 26. ? @ 0x00007f583da43850 2025.04.02 01:50:25.635225 [ 7799 ] {3c6ac7f2-9d14-4b1f-a18f-46ec797c10a0} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lastValueRespectNulls(NULL, NULL, NULL);) 2025.04.02 01:50:25.639775 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:25.707554 [ 7799 ] {16453be6-89d8-4c90-af72-3d4dfbae5510} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT last_value_respect_nulls(NULL, NULL, NULL);) 2025.04.02 01:50:25.711355 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:25.732648 [ 7799 ] {6f816d18-c4ba-4556-ac4c-ee213a9fc44b} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lcase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lcase(NULL, NULL, NULL);) 2025.04.02 01:50:25.736693 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lcase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:25.756791 [ 7799 ] {2077c7b8-4951-4d5a-92b4-ef33497d4e34} executeQuery: Code: 42. DB::Exception: Number of arguments for function lcm doesn't match: passed 3, should be 2: In scope SELECT lcm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lcm(NULL, NULL, NULL);) 2025.04.02 01:50:25.760476 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lcm doesn't match: passed 3, should be 2: In scope SELECT lcm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:25.782233 [ 7799 ] {2935e91a-5460-4026-9cbb-2ea4b66d4fd8} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT leadInFrame(NULL, NULL, NULL);) 2025.04.02 01:50:25.782927 [ 13505 ] {2d9cfb30-ebbb-4f93-8c2c-ca219764f098} executeQuery: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_mutation' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because mutations cannot work with these settings. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45776) (comment: 01419_merge_tree_settings_sanity_check.sql) (in query: CREATE TABLE mytable_local (`created` DateTime, `eventday` Date, `user_id` UInt32) ENGINE = MergeTree PARTITION BY toYYYYMM(eventday) ORDER BY (eventday, user_id) SETTINGS number_of_free_entries_in_pool_to_execute_mutation = 100, index_granularity = 191, min_bytes_for_wide_part = 997484786, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 8, min_bytes_for_full_part_storage = 87966909, compact_parts_max_bytes_to_buffer = 354155546, compact_parts_max_granules_to_buffer = 146, compact_parts_merge_max_bytes_to_prefetch_part = 26448890, merge_max_block_size = 17069, old_parts_lifetime = 93., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 19413880, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 38008, primary_key_compress_block_size = 24231, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception const&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x000000003e5d5acd 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:417: DB::MergeTreeSettingsImpl::sanityCheck(unsigned long, bool, bool) const @ 0x000000003e5694da 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:663: DB::MergeTreeSettings::sanityCheck(unsigned long, bool, bool) const @ 0x000000003e56fb85 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:478: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003ddeea66 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:130: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003eaab85f 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003eaa9b2a 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003ea9a926 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000033526b3a 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003c9464fa 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377e8869 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 17. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 18. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 24. ? @ 0x00007f583d9b1ac3 25. ? @ 0x00007f583da43850 2025.04.02 01:50:25.785623 [ 7799 ] {} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.04.02 01:50:25.787069 [ 13505 ] {} TCPHandler: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_mutation' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because mutations cannot work with these settings. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception const&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x000000003e5d5acd 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:417: DB::MergeTreeSettingsImpl::sanityCheck(unsigned long, bool, bool) const @ 0x000000003e5694da 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:663: DB::MergeTreeSettings::sanityCheck(unsigned long, bool, bool) const @ 0x000000003e56fb85 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:478: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003ddeea66 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:130: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003eaab85f 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003eaa9b2a 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003ea9a926 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000033526b3a 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003c9464fa 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377e8869 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 17. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 18. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 24. ? @ 0x00007f583d9b1ac3 25. ? @ 0x00007f583da43850 2025.04.02 01:50:25.868528 [ 7799 ] {ab28fc5a-73c6-4859-9ec7-479d7fa02b4d} executeQuery: Code: 42. DB::Exception: Number of arguments for function left doesn't match: passed 3, should be 2: In scope SELECT left(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT left(NULL, NULL, NULL);) 2025.04.02 01:50:25.876703 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function left doesn't match: passed 3, should be 2: In scope SELECT left(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:25.925555 [ 17965 ] {} BaseDaemon: 1. ./build_docker/./src/Common/SignalHandlers.cpp:102: signalHandler(int, siginfo_t*, void*) @ 0x000000002117b1b7 2025.04.02 01:50:26.000137 [ 7799 ] {b52286c6-0d4a-4093-b11f-baac6d65fe1b} executeQuery: Code: 42. DB::Exception: Number of arguments for function leftUTF8 doesn't match: passed 3, should be 2: In scope SELECT leftUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT leftUTF8(NULL, NULL, NULL);) 2025.04.02 01:50:26.005995 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function leftUTF8 doesn't match: passed 3, should be 2: In scope SELECT leftUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:26.027574 [ 7799 ] {782c41ff-4d9e-4786-a60b-a38c28f221d1} executeQuery: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lemmatize(NULL, NULL, NULL);) 2025.04.02 01:50:26.032151 [ 7799 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.04.02 01:50:26.055474 [ 7799 ] {04f9b32a-1a79-446c-bada-c60db7542049} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT length(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT length(NULL, NULL, NULL);) 2025.04.02 01:50:26.060134 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT length(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:26.083627 [ 7799 ] {60bb292c-6de2-404a-96fb-ff46a9ec1a1e} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT lengthUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lengthUTF8(NULL, NULL, NULL);) 2025.04.02 01:50:26.088267 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT lengthUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:26.115478 [ 7799 ] {da8e659c-98b4-4167-9d87-8594ecd73e77} executeQuery: Code: 42. DB::Exception: Number of arguments for function less doesn't match: passed 3, should be 2: In scope SELECT less(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT less(NULL, NULL, NULL);) 2025.04.02 01:50:26.120816 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function less doesn't match: passed 3, should be 2: In scope SELECT less(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:26.144493 [ 7799 ] {f28c15a7-3219-4a94-96d0-bbe3901fe695} executeQuery: Code: 42. DB::Exception: Number of arguments for function lessOrEquals doesn't match: passed 3, should be 2: In scope SELECT lessOrEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lessOrEquals(NULL, NULL, NULL);) 2025.04.02 01:50:26.149480 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lessOrEquals doesn't match: passed 3, should be 2: In scope SELECT lessOrEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:26.176498 [ 7799 ] {6b6e6455-3f79-45ec-8003-4ac798b8870d} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT levenshteinDistance(NULL, NULL, NULL);) 2025.04.02 01:50:26.181726 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:26.208688 [ 7799 ] {60c9b42a-0c87-49e4-9c1d-5a3e4ddbf778} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT levenshteinDistanceUTF8(NULL, NULL, NULL);) 2025.04.02 01:50:26.216034 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:26.237732 [ 7799 ] {e8e8f6a6-ccb2-4882-9c50-93cbf945662d} executeQuery: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 3, should be 1: In scope SELECT lgamma(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lgamma(NULL, NULL, NULL);) 2025.04.02 01:50:26.242188 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 3, should be 1: In scope SELECT lgamma(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:26.265932 [ 7799 ] {11e08b51-1a5e-4501-8578-73afd4e12258} executeQuery: Code: 42. DB::Exception: Number of arguments for function like doesn't match: passed 3, should be 2: In scope SELECT like(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT like(NULL, NULL, NULL);) 2025.04.02 01:50:26.270608 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function like doesn't match: passed 3, should be 2: In scope SELECT like(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:26.294744 [ 7799 ] {f57bce55-22e8-475f-8642-883e97b756e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT ln(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ln(NULL, NULL, NULL);) 2025.04.02 01:50:26.300422 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT ln(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:26.362358 [ 7799 ] {e3f3142b-6935-420b-b976-b789b3a5f847} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT log(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT log(NULL, NULL, NULL);) 2025.04.02 01:50:26.366741 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT log(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:26.387821 [ 7799 ] {c8393df0-6746-4252-beee-2faef5da036f} executeQuery: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 3, should be 1: In scope SELECT log10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT log10(NULL, NULL, NULL);) 2025.04.02 01:50:26.399219 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 3, should be 1: In scope SELECT log10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:26.415977 [ 7799 ] {d1c8b845-9c52-4b5b-a8d3-eba2e403b808} executeQuery: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 3, should be 1: In scope SELECT log1p(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT log1p(NULL, NULL, NULL);) 2025.04.02 01:50:26.428003 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 3, should be 1: In scope SELECT log1p(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:26.445297 [ 7799 ] {8b977c9c-8c5e-4933-81c7-2f5dd67b1303} executeQuery: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 3, should be 1: In scope SELECT log2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT log2(NULL, NULL, NULL);) 2025.04.02 01:50:26.446656 [ 1429 ] {e85ef0ca-fbfb-4224-bc57-9780f89ef1b3} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `0x` in scope SELECT `0x`. (UNKNOWN_IDENTIFIER) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45832) (comment: 02493_inconsistent_hex_and_binary_number.expect) (in query: select 0x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000035df38a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3750: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d4223f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 18. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 19. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 25. ? @ 0x00007f583d9b1ac3 26. ? @ 0x00007f583da43850 2025.04.02 01:50:26.450935 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 3, should be 1: In scope SELECT log2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:26.451035 [ 1429 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `0x` in scope SELECT `0x`. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000035df38a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3750: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d4223f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 18. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 19. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 25. ? @ 0x00007f583d9b1ac3 26. ? @ 0x00007f583da43850 2025.04.02 01:50:26.475700 [ 7799 ] {cac086d3-f44b-40c4-9c6f-749d1fdfd83f} executeQuery: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 3, should be 1: In scope SELECT logTrace(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT logTrace(NULL, NULL, NULL);) 2025.04.02 01:50:26.480449 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 3, should be 1: In scope SELECT logTrace(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:26.504401 [ 7799 ] {02d1e661-7d10-4917-a31b-ece07e0c0793} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityIndices(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lowCardinalityIndices(NULL, NULL, NULL);) 2025.04.02 01:50:26.509601 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityIndices(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:26.533109 [ 7799 ] {1cc3a147-2281-4cd2-b2e7-18d26d3e1ff4} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityKeys(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lowCardinalityKeys(NULL, NULL, NULL);) 2025.04.02 01:50:26.540192 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityKeys(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:26.562906 [ 7799 ] {17e49c5b-199c-4d79-aaed-460e69d94241} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lower(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lower(NULL, NULL, NULL);) 2025.04.02 01:50:26.568148 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lower(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:26.571128 [ 13505 ] {41588341-6152-430d-ba6a-1cd4731d1b9a} executeQuery: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_lower_max_size_of_merge' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because the maximum size of merge will be always lowered. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45776) (comment: 01419_merge_tree_settings_sanity_check.sql) (in query: CREATE TABLE mytable_local (`created` DateTime, `eventday` Date, `user_id` UInt32) ENGINE = MergeTree PARTITION BY toYYYYMM(eventday) ORDER BY (eventday, user_id) SETTINGS number_of_free_entries_in_pool_to_lower_max_size_of_merge = 100, index_granularity = 191, min_bytes_for_wide_part = 997484786, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 8, min_bytes_for_full_part_storage = 87966909, compact_parts_max_bytes_to_buffer = 354155546, compact_parts_max_granules_to_buffer = 146, compact_parts_merge_max_bytes_to_prefetch_part = 26448890, merge_max_block_size = 17069, old_parts_lifetime = 93., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 19413880, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 38008, primary_key_compress_block_size = 24231, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception const&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x000000003e5d5acd 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:429: DB::MergeTreeSettingsImpl::sanityCheck(unsigned long, bool, bool) const @ 0x000000003e56963a 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:663: DB::MergeTreeSettings::sanityCheck(unsigned long, bool, bool) const @ 0x000000003e56fb85 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:478: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003ddeea66 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:130: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003eaab85f 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003eaa9b2a 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003ea9a926 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000033526b3a 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003c9464fa 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377e8869 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 17. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 18. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 24. ? @ 0x00007f583d9b1ac3 25. ? @ 0x00007f583da43850 2025.04.02 01:50:26.575088 [ 13505 ] {} TCPHandler: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_lower_max_size_of_merge' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because the maximum size of merge will be always lowered. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception const&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x000000003e5d5acd 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:429: DB::MergeTreeSettingsImpl::sanityCheck(unsigned long, bool, bool) const @ 0x000000003e56963a 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:663: DB::MergeTreeSettings::sanityCheck(unsigned long, bool, bool) const @ 0x000000003e56fb85 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:478: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003ddeea66 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:130: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003eaab85f 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003eaa9b2a 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003ea9a926 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000033526b3a 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003c9464fa 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377e8869 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 17. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 18. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 24. ? @ 0x00007f583d9b1ac3 25. ? @ 0x00007f583da43850 2025.04.02 01:50:26.593486 [ 7799 ] {f2df4d0a-51b3-4e12-ae69-430916eb1e3b} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 3, should be 1: In scope SELECT lowerUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT lowerUTF8(NULL, NULL, NULL);) 2025.04.02 01:50:26.599494 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 3, should be 1: In scope SELECT lowerUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:26.948617 [ 7799 ] {ebf22839-9978-4318-aa95-d171e644bf2e} executeQuery: Code: 42. DB::Exception: Function map requires even number of arguments, but 3 given: In scope SELECT map(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT map(NULL, NULL, NULL);) 2025.04.02 01:50:26.953262 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Function map requires even number of arguments, but 3 given: In scope SELECT map(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:27.152109 [ 7799 ] {218b3dc3-efd3-464d-a9e9-e8f9a4c9530a} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapContains doesn't match: passed 3, should be 2: In scope SELECT mapContains(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT mapContains(NULL, NULL, NULL);) 2025.04.02 01:50:27.156315 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapContains doesn't match: passed 3, should be 2: In scope SELECT mapContains(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:27.306408 [ 14191 ] {0c65f537-2cc4-4034-ba38-694ef9e97e5d} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `0x` in scope SELECT `0x`. (UNKNOWN_IDENTIFIER) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45860) (comment: 02493_inconsistent_hex_and_binary_number.expect) (in query: select 0x ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000035df38a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3750: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d4223f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 18. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 19. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 25. ? @ 0x00007f583d9b1ac3 26. ? @ 0x00007f583da43850 2025.04.02 01:50:27.310844 [ 14191 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `0x` in scope SELECT `0x`. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000035df38a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3750: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d4223f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 18. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 19. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 25. ? @ 0x00007f583d9b1ac3 26. ? @ 0x00007f583da43850 2025.04.02 01:50:27.318336 [ 13505 ] {0e9e2619-0651-426e-8bdd-0e53e77bcf42} executeQuery: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_optimize_entire_partition' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because the maximum size of merge will be always lowered. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45776) (comment: 01419_merge_tree_settings_sanity_check.sql) (in query: CREATE TABLE mytable_local (`created` DateTime, `eventday` Date, `user_id` UInt32) ENGINE = MergeTree PARTITION BY toYYYYMM(eventday) ORDER BY (eventday, user_id) SETTINGS number_of_free_entries_in_pool_to_execute_optimize_entire_partition = 100, index_granularity = 191, min_bytes_for_wide_part = 997484786, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 8, min_bytes_for_full_part_storage = 87966909, compact_parts_max_bytes_to_buffer = 354155546, compact_parts_max_granules_to_buffer = 146, compact_parts_merge_max_bytes_to_prefetch_part = 26448890, merge_max_block_size = 17069, old_parts_lifetime = 93., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 19413880, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 38008, primary_key_compress_block_size = 24231, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception const&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x000000003e5d5acd 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:441: DB::MergeTreeSettingsImpl::sanityCheck(unsigned long, bool, bool) const @ 0x000000003e569784 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:663: DB::MergeTreeSettings::sanityCheck(unsigned long, bool, bool) const @ 0x000000003e56fb85 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:478: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003ddeea66 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:130: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003eaab85f 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003eaa9b2a 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003ea9a926 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000033526b3a 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003c9464fa 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377e8869 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 17. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 18. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 24. ? @ 0x00007f583d9b1ac3 25. ? @ 0x00007f583da43850 2025.04.02 01:50:27.322926 [ 13505 ] {} TCPHandler: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_optimize_entire_partition' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because the maximum size of merge will be always lowered. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception const&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x000000003e5d5acd 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:441: DB::MergeTreeSettingsImpl::sanityCheck(unsigned long, bool, bool) const @ 0x000000003e569784 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:663: DB::MergeTreeSettings::sanityCheck(unsigned long, bool, bool) const @ 0x000000003e56fb85 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:478: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003ddeea66 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:130: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003eaab85f 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003eaa9b2a 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003ea9a926 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000033526b3a 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003c9464fa 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000377e8869 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000377ccf95 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000377fa795 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 17. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 18. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 24. ? @ 0x00007f583d9b1ac3 25. ? @ 0x00007f583da43850 2025.04.02 01:50:27.386005 [ 7799 ] {48d38b06-ccf0-4615-a284-6296ed700d95} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT mapFromArrays(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT mapFromArrays(NULL, NULL, NULL);) 2025.04.02 01:50:27.392014 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT mapFromArrays(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:27.471321 [ 7799 ] {5eec6787-6189-4bb7-9804-1257497b22bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 3, should be 1: In scope SELECT mapKeys(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT mapKeys(NULL, NULL, NULL);) 2025.04.02 01:50:27.477256 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 3, should be 1: In scope SELECT mapKeys(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:27.785735 [ 7799 ] {248c2bf9-0dda-40a6-99f4-f917b64a67fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 3, should be 2: In scope SELECT mapUpdate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT mapUpdate(NULL, NULL, NULL);) 2025.04.02 01:50:27.790447 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 3, should be 2: In scope SELECT mapUpdate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:27.815497 [ 7799 ] {79e4cba9-e478-4911-84e3-948b249efee5} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 3, should be 1: In scope SELECT mapValues(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT mapValues(NULL, NULL, NULL);) 2025.04.02 01:50:27.819914 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 3, should be 1: In scope SELECT mapValues(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:27.845442 [ 7799 ] {1b64dac6-5d35-4769-a70c-b7817e435b77} executeQuery: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT match(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT match(NULL, NULL, NULL);) 2025.04.02 01:50:27.850077 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT match(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:27.874604 [ 7799 ] {0523025a-0966-44ae-92ae-2a6b15d325f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 3, should be 1: In scope SELECT materialize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT materialize(NULL, NULL, NULL);) 2025.04.02 01:50:27.879344 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 3, should be 1: In scope SELECT materialize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:27.957584 [ 7799 ] {5a5974c2-7544-4bf4-b8c6-b5e428f738b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 3, should be 2: In scope SELECT max2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT max2(NULL, NULL, NULL);) 2025.04.02 01:50:27.962052 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 3, should be 2: In scope SELECT max2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:28.017847 [ 13505 ] {6ee4dc65-7f0b-435d-9506-486d25fb9245} executeQuery: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_mutation' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because mutations cannot work with these settings. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45776) (comment: 01419_merge_tree_settings_sanity_check.sql) (in query: ALTER TABLE mytable_local MODIFY SETTING number_of_free_entries_in_pool_to_execute_mutation = 100;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception const&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x000000003e5d5acd 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:417: DB::MergeTreeSettingsImpl::sanityCheck(unsigned long, bool, bool) const @ 0x000000003e5694da 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:663: DB::MergeTreeSettings::sanityCheck(unsigned long, bool, bool) const @ 0x000000003e56fb85 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3994: DB::MergeTreeData::changeSettings(std::shared_ptr const&, std::unique_lock&) @ 0x000000003dece183 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:385: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003eab8b5f 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:219: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775bf34 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 12. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 19. ? @ 0x00007f583d9b1ac3 20. ? @ 0x00007f583da43850 2025.04.02 01:50:28.023615 [ 13505 ] {} TCPHandler: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_mutation' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because mutations cannot work with these settings. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception const&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x000000003e5d5acd 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:417: DB::MergeTreeSettingsImpl::sanityCheck(unsigned long, bool, bool) const @ 0x000000003e5694da 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:663: DB::MergeTreeSettings::sanityCheck(unsigned long, bool, bool) const @ 0x000000003e56fb85 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3994: DB::MergeTreeData::changeSettings(std::shared_ptr const&, std::unique_lock&) @ 0x000000003dece183 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:385: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003eab8b5f 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:219: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003775bf34 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000377543f0 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 12. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 19. ? @ 0x00007f583d9b1ac3 20. ? @ 0x00007f583da43850 2025.04.02 01:50:28.995374 [ 17965 ] {} BaseDaemon: 2. SignalAction(int, void*, void*) @ 0x00000000088a5bae 2025.04.02 01:50:28.995597 [ 17965 ] {} BaseDaemon: 3. ? @ 0x00007f583d95f520 2025.04.02 01:50:28.995706 [ 17965 ] {} BaseDaemon: 4. ? @ 0x00007f583d9b39fd 2025.04.02 01:50:28.995812 [ 17965 ] {} BaseDaemon: 5. ? @ 0x00007f583d95f476 2025.04.02 01:50:28.995908 [ 17965 ] {} BaseDaemon: 6. ? @ 0x00007f583d9457f3 2025.04.02 01:50:29.146910 [ 7799 ] {7e6e0c95-45e1-4497-9eaf-879d6669b07a} executeQuery: Code: 42. DB::Exception: Number of arguments for function min2 doesn't match: passed 3, should be 2: In scope SELECT min2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT min2(NULL, NULL, NULL);) 2025.04.02 01:50:29.150964 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function min2 doesn't match: passed 3, should be 2: In scope SELECT min2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:29.218655 [ 7799 ] {c883377b-048b-4f72-bcb2-7d69cc68159a} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinous(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT minSampleSizeContinous(NULL, NULL, NULL);) 2025.04.02 01:50:29.223343 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinous(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:29.247336 [ 7799 ] {c4243a6e-92e6-496e-8777-7b8f305eda98} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinuous(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT minSampleSizeContinuous(NULL, NULL, NULL);) 2025.04.02 01:50:29.251581 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinuous(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:29.274997 [ 7799 ] {4f249130-a6a3-4e71-8467-358184a8c2db} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 3, should be 4: In scope SELECT minSampleSizeConversion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT minSampleSizeConversion(NULL, NULL, NULL);) 2025.04.02 01:50:29.279439 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 3, should be 4: In scope SELECT minSampleSizeConversion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:29.302867 [ 7799 ] {7b9b3655-fbae-4977-b969-4f96ecf1bab3} executeQuery: Code: 42. DB::Exception: Number of arguments for function minus doesn't match: passed 3, should be 2: In scope SELECT minus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT minus(NULL, NULL, NULL);) 2025.04.02 01:50:29.307922 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minus doesn't match: passed 3, should be 2: In scope SELECT minus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:29.331530 [ 7799 ] {443ff3ec-ceb7-4c43-8e02-c8f7ce2cb5f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT mismatches(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT mismatches(NULL, NULL, NULL);) 2025.04.02 01:50:29.335759 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT mismatches(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:29.360860 [ 7799 ] {fc83e9ae-1a9b-4b8d-8cc2-1553c0881bbb} executeQuery: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT mod(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT mod(NULL, NULL, NULL);) 2025.04.02 01:50:29.366156 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT mod(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:29.394448 [ 7799 ] {c6031598-7587-4181-a534-95aac660457c} executeQuery: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT modulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT modulo(NULL, NULL, NULL);) 2025.04.02 01:50:29.400644 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT modulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:29.421435 [ 7799 ] {5e1b0d30-469c-4dba-9354-f73b949d8316} executeQuery: Code: 42. DB::Exception: Number of arguments for function moduloLegacy doesn't match: passed 3, should be 2: In scope SELECT moduloLegacy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT moduloLegacy(NULL, NULL, NULL);) 2025.04.02 01:50:29.425749 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function moduloLegacy doesn't match: passed 3, should be 2: In scope SELECT moduloLegacy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:29.447384 [ 7799 ] {87ffcc3a-09be-46d6-8185-75a2bab410e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function moduloOrZero doesn't match: passed 3, should be 2: In scope SELECT moduloOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT moduloOrZero(NULL, NULL, NULL);) 2025.04.02 01:50:29.452806 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function moduloOrZero doesn't match: passed 3, should be 2: In scope SELECT moduloOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:29.474380 [ 7799 ] {ff632ee3-e026-4761-b0ea-b43644b77f85} executeQuery: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 3, should be 1: In scope SELECT monthName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT monthName(NULL, NULL, NULL);) 2025.04.02 01:50:29.478620 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 3, should be 1: In scope SELECT monthName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:29.502141 [ 7799 ] {42461935-ce83-4678-aba2-d153780647f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function mortonDecode doesn't match: passed 3, should be 2: In scope SELECT mortonDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT mortonDecode(NULL, NULL, NULL);) 2025.04.02 01:50:29.506195 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mortonDecode doesn't match: passed 3, should be 2: In scope SELECT mortonDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:29.565260 [ 17965 ] {} BaseDaemon: 7. ./build_docker/./src/Common/Exception.cpp:48: DB::abortOnFailedAssertion(String const&, void* const*, unsigned long, unsigned long) @ 0x00000000206d148b 2025.04.02 01:50:29.736091 [ 7799 ] {2e8a038f-1012-4440-a5d9-f35b89ae37ba} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAllIndices doesn't match: passed 3, should be 2: In scope SELECT multiMatchAllIndices(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiMatchAllIndices(NULL, NULL, NULL);) 2025.04.02 01:50:29.740554 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAllIndices doesn't match: passed 3, should be 2: In scope SELECT multiMatchAllIndices(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:29.763103 [ 7799 ] {665b8baf-626f-4287-8f8d-b9608aa6fb98} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAny doesn't match: passed 3, should be 2: In scope SELECT multiMatchAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiMatchAny(NULL, NULL, NULL);) 2025.04.02 01:50:29.767171 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAny doesn't match: passed 3, should be 2: In scope SELECT multiMatchAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:29.793376 [ 7799 ] {f2cd2f45-478c-4eff-af3e-2bb016ab4300} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAnyIndex doesn't match: passed 3, should be 2: In scope SELECT multiMatchAnyIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiMatchAnyIndex(NULL, NULL, NULL);) 2025.04.02 01:50:29.798652 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAnyIndex doesn't match: passed 3, should be 2: In scope SELECT multiMatchAnyIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:29.826989 [ 7799 ] {d0e8e90b-13b2-43c2-b60a-d8026bd5197d} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositions(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchAllPositions(NULL, NULL, NULL);) 2025.04.02 01:50:29.831434 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositions(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:29.858824 [ 7799 ] {81db532d-69fb-4cee-803b-aba293c2bcd6} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchAllPositionsCaseInsensitive(NULL, NULL, NULL);) 2025.04.02 01:50:29.865087 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:29.890022 [ 7799 ] {db9e9218-4ef4-4f50-9ce7-882d7e146fc4} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchAllPositionsCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.04.02 01:50:29.894405 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:29.918291 [ 7799 ] {dacfb7d4-475d-4b92-9dc1-4ce747db3a6d} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchAllPositionsUTF8(NULL, NULL, NULL);) 2025.04.02 01:50:29.922609 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:29.945790 [ 7799 ] {fab16f81-3263-469e-a6b2-ffa10bf74d95} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAny doesn't match: passed 3, should be 2: In scope SELECT multiSearchAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchAny(NULL, NULL, NULL);) 2025.04.02 01:50:29.950028 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAny doesn't match: passed 3, should be 2: In scope SELECT multiSearchAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:29.974218 [ 7799 ] {702a6ef2-1fe1-48f8-879f-980c3757eaf4} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchAnyCaseInsensitive(NULL, NULL, NULL);) 2025.04.02 01:50:29.978537 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:30.002456 [ 7799 ] {a66cb910-a133-48ad-90de-1f2995aeda9a} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchAnyCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.04.02 01:50:30.008054 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:30.032743 [ 7799 ] {96017182-cc8d-4541-9629-f838ad06e9d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchAnyUTF8(NULL, NULL, NULL);) 2025.04.02 01:50:30.037126 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:30.058832 [ 7799 ] {34730549-df67-4690-a817-daaaac22f12c} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchFirstIndex(NULL, NULL, NULL);) 2025.04.02 01:50:30.063022 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:30.085340 [ 7799 ] {e6e272d4-654c-4990-8594-4f0c5bdea7da} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchFirstIndexCaseInsensitive(NULL, NULL, NULL);) 2025.04.02 01:50:30.089685 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:30.112994 [ 7799 ] {6aa90445-5d6c-4fc6-9296-fd6f120b2474} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchFirstIndexCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.04.02 01:50:30.117977 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:30.122133 [ 6489 ] {84037c94-6183-4de5-ab97-fd6a0e1ad589} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date: In scope SELECT makeDate(CAST(1980, 'Date'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45894) (comment: 02242_make_date_mysql.sql) (in query: select makeDate(cast(1980 as Date), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151627f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:50:30.124129 [ 17965 ] {} BaseDaemon: 8.0. inlined from ./build_docker/./src/Common/Exception.cpp:70: DB::handle_error_code(String const&, int, bool, std::vector> const&) 2025.04.02 01:50:30.124348 [ 17965 ] {} BaseDaemon: 8. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2e61 2025.04.02 01:50:30.126382 [ 6489 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date: In scope SELECT makeDate(CAST(1980, 'Date'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151627f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:50:30.140143 [ 7799 ] {de07b296-6422-41b5-a7e3-c6c26ae33e16} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchFirstIndexUTF8(NULL, NULL, NULL);) 2025.04.02 01:50:30.145238 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:30.149599 [ 6489 ] {bfe2608d-e019-4ce3-b2ea-7e000d71eb9f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date: In scope SELECT makeDate(CAST(-1980, 'Date'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45894) (comment: 02242_make_date_mysql.sql) (in query: select makeDate(cast(-1980 as Date), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151627f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:50:30.153295 [ 6489 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date: In scope SELECT makeDate(CAST(-1980, 'Date'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151627f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:50:30.170124 [ 7799 ] {888c2819-1769-4120-a89d-077281871427} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPosition doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPosition(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchFirstPosition(NULL, NULL, NULL);) 2025.04.02 01:50:30.175014 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPosition doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPosition(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:30.177372 [ 6489 ] {5865c8c7-b3d3-4c82-b029-7ab2d2d9e56e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date32: In scope SELECT makeDate(CAST(1980, 'Date32'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45894) (comment: 02242_make_date_mysql.sql) (in query: select makeDate(cast(1980 as Date32), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151627f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:50:30.181172 [ 6489 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date32: In scope SELECT makeDate(CAST(1980, 'Date32'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151627f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:50:30.202516 [ 7799 ] {64649a10-b88d-4697-b186-ff793578eb01} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchFirstPositionCaseInsensitive(NULL, NULL, NULL);) 2025.04.02 01:50:30.207952 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:30.232342 [ 6489 ] {aa4a6d9c-3e0b-4dcd-b50c-be790a2c5325} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date32: In scope SELECT makeDate(CAST(-1980, 'Date32'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45894) (comment: 02242_make_date_mysql.sql) (in query: select makeDate(cast(-1980 as Date32), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151627f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:50:30.233725 [ 7799 ] {9eb4cdae-81c4-4521-a4a2-89d82b1e341a} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchFirstPositionCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.04.02 01:50:30.236298 [ 6489 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date32: In scope SELECT makeDate(CAST(-1980, 'Date32'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151627f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:50:30.238636 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:30.261608 [ 6489 ] {64f92b22-62f0-463e-b847-2710af23b229} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime: In scope SELECT makeDate(CAST(1980, 'DateTime'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45894) (comment: 02242_make_date_mysql.sql) (in query: select makeDate(cast(1980 as DateTime), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151627f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:50:30.264884 [ 7799 ] {ce9811be-5159-4e96-b1bf-1af15aa160c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiSearchFirstPositionUTF8(NULL, NULL, NULL);) 2025.04.02 01:50:30.265683 [ 6489 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime: In scope SELECT makeDate(CAST(1980, 'DateTime'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151627f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:50:30.269822 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:30.292933 [ 6489 ] {38a1c3f6-c0a0-466d-83ec-3f5d14224309} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime: In scope SELECT makeDate(CAST(-1980, 'DateTime'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45894) (comment: 02242_make_date_mysql.sql) (in query: select makeDate(cast(-1980 as DateTime), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151627f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:50:30.295404 [ 7799 ] {17aeda1b-f6a0-40b6-9f05-a1bfb01176fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 3, should be 2: In scope SELECT multiply(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT multiply(NULL, NULL, NULL);) 2025.04.02 01:50:30.297451 [ 6489 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime: In scope SELECT makeDate(CAST(-1980, 'DateTime'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151627f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:50:30.300285 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 3, should be 2: In scope SELECT multiply(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:30.324989 [ 6489 ] {f8a1677c-96f9-4526-83eb-f0aca5a6e475} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate(CAST(1980, 'DateTime64'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45894) (comment: 02242_make_date_mysql.sql) (in query: select makeDate(cast(1980 as DateTime64), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151627f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:50:30.329403 [ 6489 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate(CAST(1980, 'DateTime64'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151627f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:50:30.353198 [ 6489 ] {2c005377-802c-4bd2-9cab-c2d16607659d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate(CAST(-1980, 'DateTime64'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45894) (comment: 02242_make_date_mysql.sql) (in query: select makeDate(cast(-1980 as DateTime64), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151627f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:50:30.356733 [ 6489 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate(CAST(-1980, 'DateTime64'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151627f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:50:30.374537 [ 6489 ] {d978a5c5-5753-42b3-b61c-4a6864ee4bc0} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate('1980', '10'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45894) (comment: 02242_make_date_mysql.sql) (in query: select makeDate('1980', '10');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151627f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:50:30.377901 [ 6489 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate('1980', '10'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151627f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:50:30.397203 [ 6489 ] {33d9aa17-e1f5-41b3-a49f-208c580a29d4} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate('-1980', 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45894) (comment: 02242_make_date_mysql.sql) (in query: select makeDate('-1980', 3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151627f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:50:30.401295 [ 6489 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate('-1980', 3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151627f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:50:30.411014 [ 17965 ] {} BaseDaemon: 9. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 2025.04.02 01:50:30.417931 [ 6489 ] {381cbd9c-410a-4787-8fad-1687d80a02a9} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate('aa', 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45894) (comment: 02242_make_date_mysql.sql) (in query: select makeDate('aa', 3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151627f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:50:30.421305 [ 6489 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate('aa', 3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151627f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:50:30.440095 [ 6489 ] {43cd6364-553a-4367-84d1-e9d27811062d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'dayofyear' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate(1994, 'aa'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45894) (comment: 02242_make_date_mysql.sql) (in query: select makeDate(1994, 'aa');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151627f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:50:30.443562 [ 6489 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'dayofyear' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate(1994, 'aa'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000031c411e7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000031c3c875 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000031c3b07f 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000151627f6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f17de7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000031c003bc 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000031bff680 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c01518 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 26. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 27. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 2025.04.02 01:50:30.582534 [ 7799 ] {161c8a1e-14e7-4525-919a-5dfdb9f2f5c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 3, should be 1: In scope SELECT negate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT negate(NULL, NULL, NULL);) 2025.04.02 01:50:30.587203 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 3, should be 1: In scope SELECT negate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:30.610567 [ 7799 ] {dccf4f99-4b20-479f-9211-2be732816c41} executeQuery: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT neighbor(NULL, NULL, NULL);) 2025.04.02 01:50:30.615202 [ 7799 ] {} TCPHandler: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.04.02 01:50:30.680783 [ 7799 ] {11bdcbc7-d12c-45b9-b348-f435e606f85c} executeQuery: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 3, should be 1: In scope SELECT netloc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT netloc(NULL, NULL, NULL);) 2025.04.02 01:50:30.685555 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 3, should be 1: In scope SELECT netloc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:30.696613 [ 17965 ] {} BaseDaemon: 10. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000088f4804 2025.04.02 01:50:30.706988 [ 7799 ] {01c70906-2a3d-4309-82b9-c0744f6e4921} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistance doesn't match: passed 3, should be 2: In scope SELECT ngramDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ngramDistance(NULL, NULL, NULL);) 2025.04.02 01:50:30.711649 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistance doesn't match: passed 3, should be 2: In scope SELECT ngramDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:30.734086 [ 7799 ] {5f038d41-9933-423c-b0b5-b6628440f158} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ngramDistanceCaseInsensitive(NULL, NULL, NULL);) 2025.04.02 01:50:30.738661 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:30.765546 [ 7799 ] {929aa128-234a-4aab-8796-6f5a35f587de} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ngramDistanceCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.04.02 01:50:30.772403 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:30.794718 [ 7799 ] {34c98e2d-9190-4f45-984a-5c1719a1c232} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ngramDistanceUTF8(NULL, NULL, NULL);) 2025.04.02 01:50:30.799548 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:31.173898 [ 7799 ] {c09271a7-1d0c-4ac5-a1d4-3fee5d89ca1a} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearch doesn't match: passed 3, should be 2: In scope SELECT ngramSearch(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ngramSearch(NULL, NULL, NULL);) 2025.04.02 01:50:31.179304 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearch doesn't match: passed 3, should be 2: In scope SELECT ngramSearch(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:31.201150 [ 7799 ] {169ec2cc-f159-4038-ada6-d0742665463f} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ngramSearchCaseInsensitive(NULL, NULL, NULL);) 2025.04.02 01:50:31.205846 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:31.228713 [ 7799 ] {bf7ae133-c159-43b3-b572-3c5b862a46ab} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ngramSearchCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.04.02 01:50:31.234210 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:31.257778 [ 7799 ] {bb2a81ee-ed4f-4a90-8b0d-26fdcc7426a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ngramSearchUTF8(NULL, NULL, NULL);) 2025.04.02 01:50:31.262609 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:31.471692 [ 7799 ] {5dfaf5f1-f9ee-4ba7-9def-a12728b810ab} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngrams doesn't match: passed 3, should be 2: In scope SELECT ngrams(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ngrams(NULL, NULL, NULL);) 2025.04.02 01:50:31.478071 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngrams doesn't match: passed 3, should be 2: In scope SELECT ngrams(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:31.503341 [ 7799 ] {f7116660-9629-4a89-9a9b-182e2d37a699} executeQuery: Code: 36. DB::Exception: Argument 0 must be a number, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT nonNegativeDerivative(NULL, NULL, NULL);) 2025.04.02 01:50:31.508774 [ 7799 ] {} TCPHandler: Code: 36. DB::Exception: Argument 0 must be a number, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.04.02 01:50:31.531646 [ 7799 ] {70df74e9-a6f8-479b-af12-feb608f332c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT normL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normL1(NULL, NULL, NULL);) 2025.04.02 01:50:31.536664 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT normL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:31.564290 [ 7799 ] {259787bb-1c62-4f67-aa36-1bbd9eee21aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT normL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normL2(NULL, NULL, NULL);) 2025.04.02 01:50:31.569914 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT normL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:31.595552 [ 7799 ] {a2b08f7c-3ee0-4c40-9ec0-c91840c768d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT normL2Squared(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normL2Squared(NULL, NULL, NULL);) 2025.04.02 01:50:31.601045 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT normL2Squared(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:31.629249 [ 7799 ] {7b4b0cc2-8d3f-41d7-bcdf-2ad4f11b9f5d} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT normLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normLinf(NULL, NULL, NULL);) 2025.04.02 01:50:31.635346 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT normLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:31.662912 [ 7799 ] {9b7c277f-463a-4dbf-9778-946a789cd64a} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT normLp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normLp(NULL, NULL, NULL);) 2025.04.02 01:50:31.668480 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT normLp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:31.695953 [ 7799 ] {9a3bf71b-620a-4ac8-817d-6fde8a68be5f} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizeL1(NULL, NULL, NULL);) 2025.04.02 01:50:31.701636 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:31.728802 [ 7799 ] {fd4a85db-eddb-42e5-9a03-73573a6591a1} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizeL2(NULL, NULL, NULL);) 2025.04.02 01:50:31.734884 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:31.762633 [ 7799 ] {0329af43-0bf0-4305-9024-468115e64c3c} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT normalizeLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizeLinf(NULL, NULL, NULL);) 2025.04.02 01:50:31.768565 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT normalizeLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:31.795075 [ 7799 ] {fe48d50d-46f0-483d-bdda-f8252cc2f99a} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT normalizeLp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizeLp(NULL, NULL, NULL);) 2025.04.02 01:50:31.800365 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT normalizeLp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:31.827573 [ 7799 ] {e85edb52-44d2-4b1f-affe-7708f8f66a04} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 3, should be 1: In scope SELECT normalizeQuery(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizeQuery(NULL, NULL, NULL);) 2025.04.02 01:50:31.833029 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 3, should be 1: In scope SELECT normalizeQuery(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:31.860526 [ 7799 ] {4b37d4bd-7147-4c80-a080-b33dddbb2411} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizeQueryKeepNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizeQueryKeepNames(NULL, NULL, NULL);) 2025.04.02 01:50:31.865771 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizeQueryKeepNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:31.893513 [ 7799 ] {45ad3799-14b7-47e0-8e46-c6344fe5dcda} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizeUTF8NFC(NULL, NULL, NULL);) 2025.04.02 01:50:31.899098 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:31.923387 [ 7799 ] {80114da9-4311-4ce8-9416-ba4c50b45198} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFD(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizeUTF8NFD(NULL, NULL, NULL);) 2025.04.02 01:50:31.928896 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFD(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:31.952571 [ 7799 ] {fb75e567-de56-4bbb-844e-f8df3a2a0602} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizeUTF8NFKC(NULL, NULL, NULL);) 2025.04.02 01:50:31.957561 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:31.980377 [ 7799 ] {9a998775-93a6-41e4-9477-d5784d699477} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKD(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizeUTF8NFKD(NULL, NULL, NULL);) 2025.04.02 01:50:31.984956 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKD(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:32.008254 [ 7799 ] {07219765-d0ed-4d09-b5bd-d1b752b2e9d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizedQueryHash(NULL, NULL, NULL);) 2025.04.02 01:50:32.015425 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:32.038480 [ 7799 ] {76aedd2f-32dc-4d26-8918-edc01963c260} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHashKeepNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT normalizedQueryHashKeepNames(NULL, NULL, NULL);) 2025.04.02 01:50:32.043547 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHashKeepNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:32.066571 [ 7799 ] {8146e8c7-1f49-4963-b5c9-433adc3be802} executeQuery: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 3, should be 1: In scope SELECT not(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT not(NULL, NULL, NULL);) 2025.04.02 01:50:32.071071 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 3, should be 1: In scope SELECT not(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:32.095260 [ 7799 ] {69de32c8-151e-4943-abfa-aad8ba5895ab} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 3, should be 1: In scope SELECT notEmpty(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT notEmpty(NULL, NULL, NULL);) 2025.04.02 01:50:32.100079 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 3, should be 1: In scope SELECT notEmpty(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:32.124060 [ 7799 ] {1f199deb-44c8-46c9-a8bd-d3182583506e} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEquals doesn't match: passed 3, should be 2: In scope SELECT notEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT notEquals(NULL, NULL, NULL);) 2025.04.02 01:50:32.128801 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEquals doesn't match: passed 3, should be 2: In scope SELECT notEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:32.146265 [ 17965 ] {} BaseDaemon: 11. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:727: DB::RemoteQueryExecutor::processReadTaskRequest() @ 0x0000000034b283cd 2025.04.02 01:50:32.152416 [ 7799 ] {755cecec-c379-413c-8bae-b4a2e4b91711} executeQuery: Code: 42. DB::Exception: Number of arguments for function notILike doesn't match: passed 3, should be 2: In scope SELECT notILike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT notILike(NULL, NULL, NULL);) 2025.04.02 01:50:32.157068 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notILike doesn't match: passed 3, should be 2: In scope SELECT notILike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:32.182259 [ 7799 ] {bbeb162b-d848-47bf-825d-fc0f3c197a7f} executeQuery: Code: 42. DB::Exception: Function 'notIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT notIn(NULL, NULL, NULL);) 2025.04.02 01:50:32.187447 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:32.210123 [ 7799 ] {cd937b85-149b-4a4c-9dc1-e688490f9411} executeQuery: Code: 42. DB::Exception: Function 'notInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT notInIgnoreSet(NULL, NULL, NULL);) 2025.04.02 01:50:32.215752 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:32.239996 [ 7799 ] {b0b10fe1-5802-41bd-847f-f6ab537ba41d} executeQuery: Code: 42. DB::Exception: Number of arguments for function notLike doesn't match: passed 3, should be 2: In scope SELECT notLike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT notLike(NULL, NULL, NULL);) 2025.04.02 01:50:32.245153 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notLike doesn't match: passed 3, should be 2: In scope SELECT notLike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:32.269559 [ 7799 ] {01f45005-593a-4cd9-9964-dea2e837d4bc} executeQuery: Code: 42. DB::Exception: Function 'notNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT notNullIn(NULL, NULL, NULL);) 2025.04.02 01:50:32.274699 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:32.298221 [ 7799 ] {80a274b2-33f6-43ea-b13e-e40b7a2f875d} executeQuery: Code: 42. DB::Exception: Function 'notNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT notNullInIgnoreSet(NULL, NULL, NULL);) 2025.04.02 01:50:32.303359 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:32.502508 [ 7799 ] {6d83a4a2-16cd-4ccc-b5dd-2b7e40938c8f} executeQuery: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT now(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT now(NULL, NULL, NULL);) 2025.04.02 01:50:32.509028 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT now(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:32.647975 [ 7799 ] {e0db2de9-3c21-4ec9-afcc-808cb515407d} executeQuery: Code: 42. DB::Exception: Function nth_value takes exactly two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT nth_value(NULL, NULL, NULL);) 2025.04.02 01:50:32.654745 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Function nth_value takes exactly two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:32.684082 [ 7799 ] {f92629a0-a5e3-4cd8-a660-c9b9c2b0aaa5} executeQuery: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ntile(NULL, NULL, NULL);) 2025.04.02 01:50:32.690501 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:32.715013 [ 7799 ] {ae69beae-c694-4b21-948c-7eff3a1c2e25} executeQuery: Code: 42. DB::Exception: Number of arguments for function nullIf doesn't match: passed 3, should be 2: In scope SELECT nullIf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT nullIf(NULL, NULL, NULL);) 2025.04.02 01:50:32.720151 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function nullIf doesn't match: passed 3, should be 2: In scope SELECT nullIf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:32.744835 [ 7799 ] {f3a97ca7-d9d6-44c7-8229-3e8e7b2f0a70} executeQuery: Code: 42. DB::Exception: Function 'nullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT nullIn(NULL, NULL, NULL);) 2025.04.02 01:50:32.750215 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Function 'nullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:32.776946 [ 7799 ] {9318ca76-da12-49dd-9d4f-2e96a1d9f0aa} executeQuery: Code: 42. DB::Exception: Function 'nullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT nullInIgnoreSet(NULL, NULL, NULL);) 2025.04.02 01:50:32.783506 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Function 'nullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:33.505942 [ 17965 ] {} BaseDaemon: 12. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:623: DB::RemoteQueryExecutor::processPacket(DB::Packet) @ 0x0000000034b21488 2025.04.02 01:50:34.170924 [ 7799 ] {2ecc25ff-0969-4a3f-8618-4985ffbe944e} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 3, should be 1: In scope SELECT parseReadableSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT parseReadableSize(NULL, NULL, NULL);) 2025.04.02 01:50:34.175715 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 3, should be 1: In scope SELECT parseReadableSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:34.200720 [ 7799 ] {6a3445fb-8d84-4dbe-b9db-b3cddc696e29} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT parseReadableSizeOrNull(NULL, NULL, NULL);) 2025.04.02 01:50:34.205831 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:34.227216 [ 7799 ] {1c7c9876-3e1e-4050-8dfd-788552cfe538} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT parseReadableSizeOrZero(NULL, NULL, NULL);) 2025.04.02 01:50:34.232649 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:34.373028 [ 7799 ] {c5f44d23-ddd6-44a8-bf3e-0c70303f15e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 3, should be 1: In scope SELECT path(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT path(NULL, NULL, NULL);) 2025.04.02 01:50:34.377756 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 3, should be 1: In scope SELECT path(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:34.401241 [ 7799 ] {1bd14084-7b0d-485e-9ab6-eca6f915596a} executeQuery: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 3, should be 1: In scope SELECT pathFull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT pathFull(NULL, NULL, NULL);) 2025.04.02 01:50:34.406157 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 3, should be 1: In scope SELECT pathFull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:34.452860 [ 7799 ] {5289ba6d-85b8-4995-aa31-d4c7064bccf2} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT percentRank(NULL, NULL, NULL);) 2025.04.02 01:50:34.460953 [ 7799 ] {} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.04.02 01:50:34.501848 [ 7799 ] {f76e463d-07c3-4c67-a6cf-80b79fbf891b} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT percent_rank(NULL, NULL, NULL);) 2025.04.02 01:50:34.508164 [ 7799 ] {} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.04.02 01:50:34.528688 [ 7799 ] {a90ecc43-0d21-47b1-821d-c3da951d6108} executeQuery: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 3, should be 0: In scope SELECT pi(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT pi(NULL, NULL, NULL);) 2025.04.02 01:50:34.533042 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 3, should be 0: In scope SELECT pi(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:34.558822 [ 7799 ] {accf011d-9ba5-469b-bd9c-189fed7aac3f} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 3, should be 2: In scope SELECT plus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT plus(NULL, NULL, NULL);) 2025.04.02 01:50:34.563540 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 3, should be 2: In scope SELECT plus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:34.585588 [ 7799 ] {c2b34202-b958-42ba-bfac-f7357c2f7e7a} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT pmod(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT pmod(NULL, NULL, NULL);) 2025.04.02 01:50:34.590196 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT pmod(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:34.692863 [ 7799 ] {c882d659-0498-4839-b9c2-1c68fb0a07e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonAreaCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonAreaCartesian(NULL, NULL, NULL);) 2025.04.02 01:50:34.697752 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonAreaCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:34.718830 [ 7799 ] {bf64d878-4caf-431f-894d-7b2e07ee0442} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonAreaSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonAreaSpherical(NULL, NULL, NULL);) 2025.04.02 01:50:34.723402 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonAreaSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:34.745332 [ 7799 ] {213a1003-c487-47b9-a60f-c68fe7afaf45} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonConvexHullCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonConvexHullCartesian(NULL, NULL, NULL);) 2025.04.02 01:50:34.749734 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonConvexHullCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:34.771946 [ 7799 ] {90de5e95-c8fc-44fe-870d-f6e152014b21} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonPerimeterCartesian(NULL, NULL, NULL);) 2025.04.02 01:50:34.776456 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:34.798939 [ 7799 ] {65f59024-5e28-4a8a-be48-36fd97154b14} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonPerimeterSpherical(NULL, NULL, NULL);) 2025.04.02 01:50:34.803461 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:34.826197 [ 7799 ] {6be5275b-5584-4b44-883d-0adc19e1e35e} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsDistanceCartesian(NULL, NULL, NULL);) 2025.04.02 01:50:34.830775 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:34.854816 [ 7799 ] {5e51c024-084e-47c9-89f0-2531fc23b579} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsDistanceSpherical(NULL, NULL, NULL);) 2025.04.02 01:50:34.855341 [ 17965 ] {} BaseDaemon: 13. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:562: DB::RemoteQueryExecutor::readAsync() @ 0x0000000034b25dc3 2025.04.02 01:50:34.859542 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:34.883630 [ 7799 ] {6038340d-af3d-478f-8099-736ae5e506a6} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsEqualsCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsEqualsCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsEqualsCartesian(NULL, NULL, NULL);) 2025.04.02 01:50:34.888592 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsEqualsCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsEqualsCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:34.911432 [ 7799 ] {70bb3c15-ef5e-4404-beb3-0947ad13dc3b} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsIntersectionCartesian(NULL, NULL, NULL);) 2025.04.02 01:50:34.916224 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:34.939254 [ 7799 ] {0ec902ba-df38-451c-bd60-fec42a582c9e} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsIntersectionSpherical(NULL, NULL, NULL);) 2025.04.02 01:50:34.943858 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:34.966520 [ 7799 ] {73aad75f-a615-422e-8120-06ba4c7f022a} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsSymDifferenceCartesian(NULL, NULL, NULL);) 2025.04.02 01:50:34.971163 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:34.996489 [ 7799 ] {5af157ab-9a57-40cd-a81d-755d5ad11a2f} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsSymDifferenceSpherical(NULL, NULL, NULL);) 2025.04.02 01:50:35.001439 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:35.024976 [ 7799 ] {3c4944b5-8297-4606-8f65-ce83f8edad08} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsUnionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsUnionCartesian(NULL, NULL, NULL);) 2025.04.02 01:50:35.029427 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsUnionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:35.052585 [ 7799 ] {3244598f-0060-4076-9cba-1ee6a8bb0409} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsUnionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsUnionSpherical(NULL, NULL, NULL);) 2025.04.02 01:50:35.057254 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsUnionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:35.082850 [ 7799 ] {fe03047b-89fa-49c7-9124-31d83d783320} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsWithinCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsWithinCartesian(NULL, NULL, NULL);) 2025.04.02 01:50:35.087930 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsWithinCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:35.112850 [ 7799 ] {20296525-0f33-42de-b8f8-371796e82d95} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsWithinSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT polygonsWithinSpherical(NULL, NULL, NULL);) 2025.04.02 01:50:35.117921 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsWithinSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:35.184755 [ 17965 ] {} BaseDaemon: 14. ./build_docker/./src/Processors/Sources/RemoteSource.cpp:182: DB::RemoteSource::tryGenerate() @ 0x0000000040415925 2025.04.02 01:50:35.384766 [ 7799 ] {95d6b724-6960-4c07-be60-5a8373fb58f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positiveModulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT positiveModulo(NULL, NULL, NULL);) 2025.04.02 01:50:35.389180 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positiveModulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:35.411491 [ 7799 ] {8cd81fc2-5dd8-4fc9-a127-b8662bc4d178} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positive_modulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT positive_modulo(NULL, NULL, NULL);) 2025.04.02 01:50:35.416042 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positive_modulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:35.437885 [ 17965 ] {} BaseDaemon: 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003f6e8571 2025.04.02 01:50:35.438953 [ 7799 ] {58ad1a3e-dcd2-46f5-9dcb-82acceece885} executeQuery: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT pow(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT pow(NULL, NULL, NULL);) 2025.04.02 01:50:35.443796 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT pow(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:35.465480 [ 7799 ] {b1e069c5-9f1c-4fae-b501-49333818b1e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT power(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT power(NULL, NULL, NULL);) 2025.04.02 01:50:35.470207 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT power(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:35.538916 [ 7799 ] {2712724c-c99e-4085-8a00-c89484fd662e} executeQuery: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 3, should be 6: In scope SELECT proportionsZTest(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT proportionsZTest(NULL, NULL, NULL);) 2025.04.02 01:50:35.543784 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 3, should be 6: In scope SELECT proportionsZTest(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:35.568251 [ 7799 ] {9a480335-b703-4b5a-8e8d-7a1eb910bf80} executeQuery: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 3, should be 1: In scope SELECT protocol(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT protocol(NULL, NULL, NULL);) 2025.04.02 01:50:35.572758 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 3, should be 1: In scope SELECT protocol(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:35.595127 [ 7799 ] {b3110a3f-8919-4dc4-b09e-d2726c456745} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 3, should be 1: In scope SELECT punycodeDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT punycodeDecode(NULL, NULL, NULL);) 2025.04.02 01:50:35.599638 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 3, should be 1: In scope SELECT punycodeDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:35.622236 [ 7799 ] {64b13c56-ca12-41a1-aa50-ba28b68a5e49} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 3, should be 1: In scope SELECT punycodeEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT punycodeEncode(NULL, NULL, NULL);) 2025.04.02 01:50:35.626655 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 3, should be 1: In scope SELECT punycodeEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:35.728878 [ 17965 ] {} BaseDaemon: 16. ./build_docker/./src/Processors/Sources/RemoteSource.cpp:134: DB::RemoteSource::work() @ 0x0000000040414fb0 2025.04.02 01:50:35.861080 [ 17965 ] {} BaseDaemon: 17.0. inlined from ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::executeJob(DB::ExecutingGraph::Node*, DB::ReadProgressCallback*) 2025.04.02 01:50:35.861263 [ 17965 ] {} BaseDaemon: 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:98: DB::ExecutionThreadContext::executeTask() @ 0x000000003f7538b1 2025.04.02 01:50:36.201114 [ 17965 ] {} BaseDaemon: 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003f71eb14 2025.04.02 01:50:36.531390 [ 17965 ] {} BaseDaemon: 19.0. inlined from ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeSingleThread(unsigned long) 2025.04.02 01:50:36.531561 [ 17965 ] {} BaseDaemon: 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:442: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003f71c8c3 2025.04.02 01:50:36.533723 [ 7799 ] {09c0650f-9e08-4a84-8636-0828da064eba} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantiles. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantiles(NULL, NULL, NULL);) 2025.04.02 01:50:36.537986 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantiles. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:36.560538 [ 7799 ] {9c428d94-d478-4f8a-b494-797ee1476da5} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesBFloat16(NULL, NULL, NULL);) 2025.04.02 01:50:36.565075 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:36.639616 [ 7799 ] {e2a28d56-d618-421e-ac7a-3baaf8147602} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDD. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesDD(NULL, NULL, NULL);) 2025.04.02 01:50:36.644402 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDD. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:36.670397 [ 7799 ] {cbae56c6-061f-452c-97d0-ff6149895d06} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesDeterministic(NULL, NULL, NULL);) 2025.04.02 01:50:36.675493 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:36.698258 [ 7799 ] {161d37f0-cb4e-48b1-950c-7e73895ed18f} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExact. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesExact(NULL, NULL, NULL);) 2025.04.02 01:50:36.703544 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExact. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:36.728130 [ 7799 ] {ec5ac6fc-96a6-4bfb-8468-679f73b93330} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesExactExclusive(NULL, NULL, NULL);) 2025.04.02 01:50:36.733220 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:36.758221 [ 7799 ] {e449d296-5802-4b58-a01e-8a36b0dff199} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesExactHigh(NULL, NULL, NULL);) 2025.04.02 01:50:36.764051 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:36.791595 [ 7799 ] {d191ae22-d6b1-4dca-99ca-1c1f18024183} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesExactInclusive(NULL, NULL, NULL);) 2025.04.02 01:50:36.797123 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:36.821990 [ 7799 ] {080af18b-71da-47bc-a76d-bffdcd47e6af} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesExactLow(NULL, NULL, NULL);) 2025.04.02 01:50:36.827806 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:36.858089 [ 7799 ] {ca926764-9cfd-4190-9a51-6347ca2c8c41} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesExactWeighted(NULL, NULL, NULL);) 2025.04.02 01:50:36.864454 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:36.868497 [ 17965 ] {} BaseDaemon: 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003f71c2f5 2025.04.02 01:50:36.889426 [ 7799 ] {7544a870-433c-432e-8240-76686388f23d} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeightedInterpolated. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesExactWeightedInterpolated(NULL, NULL, NULL);) 2025.04.02 01:50:36.894952 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeightedInterpolated. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:36.925658 [ 7799 ] {87588893-4856-49c4-a1dc-1681bdbd9f06} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesGK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesGK(NULL, NULL, NULL);) 2025.04.02 01:50:36.930965 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesGK. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:36.953442 [ 7799 ] {a0b23424-6d86-4352-98bf-7ab6650428ce} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesInterpolatedWeighted(NULL, NULL, NULL);) 2025.04.02 01:50:36.958517 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:36.983274 [ 7799 ] {557e84bd-b997-4054-b545-ce94f4954c7e} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesTDigest(NULL, NULL, NULL);) 2025.04.02 01:50:36.989199 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:37.014664 [ 7799 ] {dedc6410-a179-4ca3-8163-81ce7bb433ae} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesTDigestWeighted(NULL, NULL, NULL);) 2025.04.02 01:50:37.020895 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:37.034529 [ 17965 ] {} BaseDaemon: 21.0. inlined from ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:49: DB::threadFunction(DB::CompletedPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) 2025.04.02 01:50:37.034674 [ 17965 ] {} BaseDaemon: 21.1. inlined from ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:89: operator() 2025.04.02 01:50:37.034757 [ 17965 ] {} BaseDaemon: 21.2. inlined from ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? 2025.04.02 01:50:37.034898 [ 17965 ] {} BaseDaemon: 21.3. inlined from ./contrib/llvm-project/libcxx/include/tuple:1789: _ZNSt3__118__apply_tuple_implB6v15007IRZN2DB25CompletedPipelineExecutor7executeEvE3$_0RNS_5tupleIJEEETpTnmJEEEDcOT_OT0_NS_15__tuple_indicesIJXspT1_EEEE 2025.04.02 01:50:37.035027 [ 17965 ] {} BaseDaemon: 21.4. inlined from ./contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15007]&>(DB::CompletedPipelineExecutor::execute()::$_0&, std::tuple<>&) 2025.04.02 01:50:37.035165 [ 17965 ] {} BaseDaemon: 21.5. inlined from ./src/Common/ThreadPool.h:311: operator() 2025.04.02 01:50:37.035254 [ 17965 ] {} BaseDaemon: 21.6. inlined from ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? 2025.04.02 01:50:37.035345 [ 17965 ] {} BaseDaemon: 21.7. inlined from ./contrib/llvm-project/libcxx/include/__functional/invoke.h:479: ? 2025.04.02 01:50:37.035436 [ 17965 ] {} BaseDaemon: 21.8. inlined from ./contrib/llvm-project/libcxx/include/__functional/function.h:235: ? 2025.04.02 01:50:37.035527 [ 17965 ] {} BaseDaemon: 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003f719de5 2025.04.02 01:50:37.043658 [ 7799 ] {a67ae2fc-a911-42eb-bb58-f036130de278} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTiming. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesTiming(NULL, NULL, NULL);) 2025.04.02 01:50:37.048419 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTiming. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:37.072583 [ 7799 ] {10a3a497-af99-4e0c-b1f7-d041ae58bd5d} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT quantilesTimingWeighted(NULL, NULL, NULL);) 2025.04.02 01:50:37.078183 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:37.104798 [ 7799 ] {c980e9c6-2e43-4802-9295-7bfab10d1b19} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT queryID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT queryID(NULL, NULL, NULL);) 2025.04.02 01:50:37.110325 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT queryID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:37.136540 [ 7799 ] {15ad2792-f76b-45fe-961c-9d73e04b72d9} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 3, should be 1: In scope SELECT queryString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT queryString(NULL, NULL, NULL);) 2025.04.02 01:50:37.141836 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 3, should be 1: In scope SELECT queryString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:37.166481 [ 7799 ] {3d37dd6e-6ed4-4ad1-b0b3-527e6647986a} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT queryStringAndFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT queryStringAndFragment(NULL, NULL, NULL);) 2025.04.02 01:50:37.171625 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT queryStringAndFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:37.198812 [ 7799 ] {9737e66f-afaf-4bb2-a2d4-04c6c6094042} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT query_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT query_id(NULL, NULL, NULL);) 2025.04.02 01:50:37.205395 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT query_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:37.227669 [ 7799 ] {e31a2962-2aad-42e4-8dd9-0aeb25b573b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 3, should be 1: In scope SELECT radians(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT radians(NULL, NULL, NULL);) 2025.04.02 01:50:37.232267 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 3, should be 1: In scope SELECT radians(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:37.255216 [ 7799 ] {942f4589-3264-471a-af55-0ced4221b6e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT rand(NULL, NULL, NULL);) 2025.04.02 01:50:37.259712 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:37.281302 [ 7799 ] {07f0ae82-773f-4f3a-86fb-a08b3a80049c} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT rand32(NULL, NULL, NULL);) 2025.04.02 01:50:37.286123 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:37.302717 [ 17965 ] {} BaseDaemon: 22.0. inlined from ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? 2025.04.02 01:50:37.302922 [ 17965 ] {} BaseDaemon: 22.1. inlined from ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? 2025.04.02 01:50:37.303041 [ 17965 ] {} BaseDaemon: 22. ./build_docker/./src/Common/ThreadPool.cpp:785: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000209762ca 2025.04.02 01:50:37.307552 [ 7799 ] {6ee2427c-c8bd-4628-a0c2-7b26cb9784a6} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand64 doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT rand64(NULL, NULL, NULL);) 2025.04.02 01:50:37.311677 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand64 doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:37.412696 [ 7799 ] {500abcff-44e1-466e-a015-fa8e3422177f} executeQuery: Code: 42. DB::Exception: Number of arguments for function randCanonical doesn't match: passed 3, should be 0 or 1.: In scope SELECT randCanonical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT randCanonical(NULL, NULL, NULL);) 2025.04.02 01:50:37.417026 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randCanonical doesn't match: passed 3, should be 0 or 1.: In scope SELECT randCanonical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:37.476021 [ 7799 ] {60f25a2a-c24d-4ea4-b4ed-c7f58dc81429} executeQuery: Code: 42. DB::Exception: Number of arguments for function randConstant doesn't match: passed 3, should be 0 or 1.: In scope SELECT randConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT randConstant(NULL, NULL, NULL);) 2025.04.02 01:50:37.480497 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randConstant doesn't match: passed 3, should be 0 or 1.: In scope SELECT randConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:37.781462 [ 17965 ] {} BaseDaemon: 23.0. inlined from ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? 2025.04.02 01:50:37.781796 [ 17965 ] {} BaseDaemon: 23.1. inlined from ./contrib/llvm-project/libcxx/include/thread:284: void std::__thread_execute[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*, 2ul>(std::tuple>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>&, std::__tuple_indices<2ul>) 2025.04.02 01:50:37.781922 [ 17965 ] {} BaseDaemon: 23. ./contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000020988a64 2025.04.02 01:50:37.782036 [ 17965 ] {} BaseDaemon: 24. ? @ 0x00007f583d9b1ac3 2025.04.02 01:50:37.782114 [ 17965 ] {} BaseDaemon: 25. ? @ 0x00007f583da43850 2025.04.02 01:50:37.864927 [ 7799 ] {1ade44f3-9e4e-4c24-8721-ff68b8089582} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 3, should be 1: In scope SELECT randomFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT randomFixedString(NULL, NULL, NULL);) 2025.04.02 01:50:37.870903 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 3, should be 1: In scope SELECT randomFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:37.987331 [ 7799 ] {6519edb0-56a4-455b-95c3-dc049ef06484} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 3, should be 1: In scope SELECT randomStringUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT randomStringUTF8(NULL, NULL, NULL);) 2025.04.02 01:50:37.992904 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 3, should be 1: In scope SELECT randomStringUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:38.084945 [ 7799 ] {52668ce2-a478-4436-80d1-eea3611c5d38} executeQuery: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT rank(NULL, NULL, NULL);) 2025.04.02 01:50:38.092822 [ 7799 ] {} TCPHandler: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.04.02 01:50:38.170251 [ 7799 ] {6f425360-83cb-4746-9495-e20e7413e252} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTLineString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT readWKTLineString(NULL, NULL, NULL);) 2025.04.02 01:50:38.174897 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTLineString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:38.198409 [ 7799 ] {7dac139d-8e67-4804-9745-e3ff5ec27109} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiLineString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT readWKTMultiLineString(NULL, NULL, NULL);) 2025.04.02 01:50:38.203522 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiLineString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:38.226489 [ 7799 ] {abb769ea-9efe-4cfb-b897-5717b3a22837} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiPolygon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT readWKTMultiPolygon(NULL, NULL, NULL);) 2025.04.02 01:50:38.231197 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiPolygon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:38.254251 [ 7799 ] {20fc4691-ffd8-4828-b49e-83cf9e20840e} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 3, should be 1: In scope SELECT readWKTPoint(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT readWKTPoint(NULL, NULL, NULL);) 2025.04.02 01:50:38.258923 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 3, should be 1: In scope SELECT readWKTPoint(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:38.280941 [ 7799 ] {5a6fa616-a405-4393-8c75-ac666d0e0a38} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTPolygon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT readWKTPolygon(NULL, NULL, NULL);) 2025.04.02 01:50:38.285398 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTPolygon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:38.308996 [ 7799 ] {9f0f6942-5446-4d5f-a3c6-2e9b479e2a44} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 3, should be 1: In scope SELECT readWKTRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT readWKTRing(NULL, NULL, NULL);) 2025.04.02 01:50:38.314289 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 3, should be 1: In scope SELECT readWKTRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:38.376932 [ 7799 ] {efa82d26-3d39-460a-a568-03f7626de6c4} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 3, should be 1: In scope SELECT regexpQuoteMeta(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT regexpQuoteMeta(NULL, NULL, NULL);) 2025.04.02 01:50:38.381411 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 3, should be 1: In scope SELECT regexpQuoteMeta(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:38.864262 [ 7799 ] {bf691cc2-169b-47b2-ba08-e0c3d072fc4e} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpret doesn't match: passed 3, should be 2: In scope SELECT reinterpret(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpret(NULL, NULL, NULL);) 2025.04.02 01:50:38.869181 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpret doesn't match: passed 3, should be 2: In scope SELECT reinterpret(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:38.891702 [ 7799 ] {8a423a1f-fab6-4acb-86f0-141363441d90} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsDate(NULL, NULL, NULL);) 2025.04.02 01:50:38.896359 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:38.919116 [ 7799 ] {6acf1e05-28df-45b6-ad9e-56cae5bf06c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDateTime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsDateTime(NULL, NULL, NULL);) 2025.04.02 01:50:38.923675 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDateTime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:38.946984 [ 7799 ] {b10a0ce5-07bc-4600-88fa-1bc6cc722e5b} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsFixedString(NULL, NULL, NULL);) 2025.04.02 01:50:38.951487 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:38.971970 [ 7799 ] {05a4f0aa-24db-42ab-a16c-1cfcd9542fec} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsFloat32(NULL, NULL, NULL);) 2025.04.02 01:50:38.976297 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:39.001879 [ 7799 ] {46d6bc54-a322-4496-850f-1f234b25aba8} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsFloat64(NULL, NULL, NULL);) 2025.04.02 01:50:39.010941 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:39.035790 [ 7799 ] {6673dac6-2bf4-4a3e-9b2c-572f51a5e0d6} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt128(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsInt128(NULL, NULL, NULL);) 2025.04.02 01:50:39.041182 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt128(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:39.064953 [ 7799 ] {7ca7436c-599b-40ba-90e3-e6eda507c3b6} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsInt16(NULL, NULL, NULL);) 2025.04.02 01:50:39.070625 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:39.091920 [ 7799 ] {694db5a4-4291-423b-95e2-c0c49289e4d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsInt256(NULL, NULL, NULL);) 2025.04.02 01:50:39.096434 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:39.117046 [ 7799 ] {dc69c694-1ab8-46fd-80b3-c2b1ea31818c} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsInt32(NULL, NULL, NULL);) 2025.04.02 01:50:39.121399 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:39.143891 [ 7799 ] {1a27d7d8-6904-4f2f-a4aa-655ee13e7063} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsInt64(NULL, NULL, NULL);) 2025.04.02 01:50:39.148398 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:39.169985 [ 7799 ] {c1219a6e-842e-44a8-8511-3ed048ab1a7e} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsInt8(NULL, NULL, NULL);) 2025.04.02 01:50:39.174512 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:39.195008 [ 7799 ] {9d0c4d24-fa9d-4f27-b5c5-db14f94f9043} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsString(NULL, NULL, NULL);) 2025.04.02 01:50:39.199581 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:39.222420 [ 7799 ] {f01bc482-defc-4495-9946-7f962ba1dd9a} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt128(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsUInt128(NULL, NULL, NULL);) 2025.04.02 01:50:39.227617 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt128(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:39.251820 [ 7799 ] {7eaaf55e-fcef-4b30-bb30-bf93621938fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsUInt16(NULL, NULL, NULL);) 2025.04.02 01:50:39.257023 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:39.279198 [ 7799 ] {fa37fc4b-051b-4eac-a8a3-6edc4242fffe} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsUInt256(NULL, NULL, NULL);) 2025.04.02 01:50:39.284317 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:39.305562 [ 7799 ] {41d45c19-8416-4669-a507-c9cc11f2db68} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsUInt32(NULL, NULL, NULL);) 2025.04.02 01:50:39.310642 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:39.336610 [ 7799 ] {18d94ace-cd33-4fb4-9cc9-ef081c1abe1c} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsUInt64(NULL, NULL, NULL);) 2025.04.02 01:50:39.342187 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:39.369463 [ 7799 ] {6ca0e9fb-2b88-461a-bb55-ba8bb3ba4beb} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsUInt8(NULL, NULL, NULL);) 2025.04.02 01:50:39.376350 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:39.400413 [ 7799 ] {dee97ab2-8df6-4351-aa49-895cee52c1d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUUID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reinterpretAsUUID(NULL, NULL, NULL);) 2025.04.02 01:50:39.406034 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUUID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:39.429904 [ 7799 ] {f0290a1a-0f56-44aa-bbfd-ffc1169fc25c} executeQuery: Code: 42. DB::Exception: Number of arguments for function repeat doesn't match: passed 3, should be 2: In scope SELECT repeat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT repeat(NULL, NULL, NULL);) 2025.04.02 01:50:39.435476 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function repeat doesn't match: passed 3, should be 2: In scope SELECT repeat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:39.666961 [ 7799 ] {f7b09f3d-748d-4b11-99dc-700a633a7906} executeQuery: Code: 43. DB::Exception: Argument 2 for function replicate must be array.: In scope SELECT replicate(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT replicate(NULL, NULL, NULL);) 2025.04.02 01:50:39.672031 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: Argument 2 for function replicate must be array.: In scope SELECT replicate(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:39.744241 [ 7799 ] {e8c3a5f7-a5af-4f75-a5d4-f5675a4c8d3a} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 3, should be 1: In scope SELECT reverse(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reverse(NULL, NULL, NULL);) 2025.04.02 01:50:39.749116 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 3, should be 1: In scope SELECT reverse(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:39.773481 [ 7799 ] {2e36e366-c960-452c-9d3e-c6fa46f76437} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 3, should be 1: In scope SELECT reverseUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT reverseUTF8(NULL, NULL, NULL);) 2025.04.02 01:50:39.778394 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 3, should be 1: In scope SELECT reverseUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:39.798875 [ 7799 ] {5ceb4970-36b4-4e3c-8409-8ddfdbb0acf8} executeQuery: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 3, should be 0: In scope SELECT revision(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT revision(NULL, NULL, NULL);) 2025.04.02 01:50:39.803314 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 3, should be 0: In scope SELECT revision(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:39.825806 [ 7799 ] {f8447a35-a219-4c96-918f-b35b54b54992} executeQuery: Code: 42. DB::Exception: Number of arguments for function right doesn't match: passed 3, should be 2: In scope SELECT right(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT right(NULL, NULL, NULL);) 2025.04.02 01:50:39.829956 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function right doesn't match: passed 3, should be 2: In scope SELECT right(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:39.935113 [ 7799 ] {73f859c7-f000-49fc-9446-6053ffbcf1ee} executeQuery: Code: 42. DB::Exception: Number of arguments for function rightUTF8 doesn't match: passed 3, should be 2: In scope SELECT rightUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT rightUTF8(NULL, NULL, NULL);) 2025.04.02 01:50:39.939702 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rightUTF8 doesn't match: passed 3, should be 2: In scope SELECT rightUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:40.000915 [ 7799 ] {bbdf1a80-90c5-40d9-aad7-0c843831da6c} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 3, should be 1: In scope SELECT roundAge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT roundAge(NULL, NULL, NULL);) 2025.04.02 01:50:40.005638 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 3, should be 1: In scope SELECT roundAge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:40.070133 [ 7799 ] {08435d8b-7450-43c9-84af-309e01579382} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDown doesn't match: passed 3, should be 2: In scope SELECT roundDown(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT roundDown(NULL, NULL, NULL);) 2025.04.02 01:50:40.074807 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDown doesn't match: passed 3, should be 2: In scope SELECT roundDown(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:40.101903 [ 7799 ] {c94f1b93-9e64-4d73-b61d-8848318b2099} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 3, should be 1: In scope SELECT roundDuration(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT roundDuration(NULL, NULL, NULL);) 2025.04.02 01:50:40.107702 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 3, should be 1: In scope SELECT roundDuration(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:40.132309 [ 7799 ] {5396a004-13d4-4f7e-a722-1676f9cbec47} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 3, should be 1: In scope SELECT roundToExp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT roundToExp2(NULL, NULL, NULL);) 2025.04.02 01:50:40.137437 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 3, should be 1: In scope SELECT roundToExp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:40.163190 [ 7799 ] {400a3dbb-c02a-4d6d-beb2-cd4831c39b04} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 3, should be 0: In scope SELECT rowNumberInAllBlocks(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT rowNumberInAllBlocks(NULL, NULL, NULL);) 2025.04.02 01:50:40.168224 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 3, should be 0: In scope SELECT rowNumberInAllBlocks(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:40.195589 [ 7799 ] {4c8718a2-7eef-42a3-aa29-8520ec456438} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 3, should be 0: In scope SELECT rowNumberInBlock(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT rowNumberInBlock(NULL, NULL, NULL);) 2025.04.02 01:50:40.200998 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 3, should be 0: In scope SELECT rowNumberInBlock(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:40.242274 [ 7799 ] {48ca71dc-24b0-4b3b-a4ae-44240cb00931} executeQuery: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT row_number(NULL, NULL, NULL);) 2025.04.02 01:50:40.250151 [ 7799 ] {} TCPHandler: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.04.02 01:50:40.312911 [ 7799 ] {a06e852d-2eb7-4a2f-b2eb-f3bd9ae5a8bb} executeQuery: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT runningAccumulate(NULL, NULL, NULL);) 2025.04.02 01:50:40.317375 [ 7799 ] {} TCPHandler: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.04.02 01:50:40.339449 [ 7799 ] {6309c4f7-cc7a-4ad5-b402-92b036cdcd0c} executeQuery: Code: 42. DB::Exception: Number of arguments for function runningConcurrency doesn't match: passed 3, should be 2: In scope SELECT runningConcurrency(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT runningConcurrency(NULL, NULL, NULL);) 2025.04.02 01:50:40.343936 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function runningConcurrency doesn't match: passed 3, should be 2: In scope SELECT runningConcurrency(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:40.365904 [ 7799 ] {18571403-2181-47aa-9b96-ea9af4e1a3fe} executeQuery: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT runningDifference(NULL, NULL, NULL);) 2025.04.02 01:50:40.371332 [ 7799 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.04.02 01:50:40.394949 [ 7799 ] {3595750e-db6e-4c3b-ad34-542debfa58dc} executeQuery: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT runningDifferenceStartingWithFirstValue(NULL, NULL, NULL);) 2025.04.02 01:50:40.400264 [ 7799 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.04.02 01:50:40.459389 [ 7799 ] {56e6f292-6873-4c17-98ce-01379259259a} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 3, should be 4: In scope SELECT s2CapUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT s2CapUnion(NULL, NULL, NULL);) 2025.04.02 01:50:40.465179 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 3, should be 4: In scope SELECT s2CapUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:40.489653 [ 7799 ] {37eac621-f05b-4dcb-8f3b-8d356dfdd518} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CellsIntersect doesn't match: passed 3, should be 2: In scope SELECT s2CellsIntersect(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT s2CellsIntersect(NULL, NULL, NULL);) 2025.04.02 01:50:40.494728 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CellsIntersect doesn't match: passed 3, should be 2: In scope SELECT s2CellsIntersect(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:40.516521 [ 7799 ] {bf869db5-19c4-4098-8e0e-9b29ac69d79b} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 3, should be 1: In scope SELECT s2GetNeighbors(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT s2GetNeighbors(NULL, NULL, NULL);) 2025.04.02 01:50:40.521807 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 3, should be 1: In scope SELECT s2GetNeighbors(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:40.644461 [ 7799 ] {2be532a9-9830-49b1-96ac-9ce1ebd06c3d} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 3, should be 4: In scope SELECT s2RectIntersection(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT s2RectIntersection(NULL, NULL, NULL);) 2025.04.02 01:50:40.649638 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 3, should be 4: In scope SELECT s2RectIntersection(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:40.670819 [ 7799 ] {2cd4ca71-3d73-4b7e-b801-393751cbcb65} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 3, should be 4: In scope SELECT s2RectUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT s2RectUnion(NULL, NULL, NULL);) 2025.04.02 01:50:40.675738 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 3, should be 4: In scope SELECT s2RectUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:40.699479 [ 7799 ] {0282142f-0cf5-44d3-8cd8-9aba0de9b38d} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 3, should be 1: In scope SELECT s2ToGeo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT s2ToGeo(NULL, NULL, NULL);) 2025.04.02 01:50:40.704750 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 3, should be 1: In scope SELECT s2ToGeo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:40.727627 [ 7799 ] {41cc7fdd-b915-4a3c-a249-fa88f04d33b6} executeQuery: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT scalarProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT scalarProduct(NULL, NULL, NULL);) 2025.04.02 01:50:40.732843 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT scalarProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:40.864522 [ 7799 ] {2b04c6ef-cb22-40f9-b9dc-cceccaf7bd7c} executeQuery: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT sequenceNextNode(NULL, NULL, NULL);) 2025.04.02 01:50:40.869722 [ 7799 ] {} TCPHandler: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) 2025.04.02 01:50:40.892302 [ 7799 ] {8449fc1e-f95a-41fb-8bed-e603afd0d410} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 3, should be 2: In scope SELECT seriesDecomposeSTL(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT seriesDecomposeSTL(NULL, NULL, NULL);) 2025.04.02 01:50:40.896836 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 3, should be 2: In scope SELECT seriesDecomposeSTL(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:40.969023 [ 7799 ] {8e506210-3e7b-4b27-ba51-a2cbb42acc60} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 3, should be 1: In scope SELECT seriesPeriodDetectFFT(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT seriesPeriodDetectFFT(NULL, NULL, NULL);) 2025.04.02 01:50:40.974801 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 3, should be 1: In scope SELECT seriesPeriodDetectFFT(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:40.999511 [ 7799 ] {7e2a8ff3-5e6c-4690-afea-0a0e3bd46f54} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT serverTimeZone(NULL, NULL, NULL);) 2025.04.02 01:50:41.005690 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:41.031622 [ 7799 ] {f5b45956-9af3-45c6-b30c-2f6ef0a72e9e} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT serverTimezone(NULL, NULL, NULL);) 2025.04.02 01:50:41.037393 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:41.060409 [ 7799 ] {9930c610-144d-4f15-9fb5-78ccf8268675} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 3, should be 0: In scope SELECT serverUUID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT serverUUID(NULL, NULL, NULL);) 2025.04.02 01:50:41.065101 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 3, should be 0: In scope SELECT serverUUID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:41.089566 [ 7799 ] {376625bf-20c9-435a-ab8a-0ec84bf4f9b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 3, should be 0: In scope SELECT shardCount(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT shardCount(NULL, NULL, NULL);) 2025.04.02 01:50:41.094780 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 3, should be 0: In scope SELECT shardCount(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:41.117389 [ 7799 ] {c6155e01-9f6f-46dd-a6b2-da6f0b9138c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 3, should be 0: In scope SELECT shardNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT shardNum(NULL, NULL, NULL);) 2025.04.02 01:50:41.123364 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 3, should be 0: In scope SELECT shardNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:41.142507 [ 7799 ] {ca78e876-693d-4bda-8087-4e0a6234699a} executeQuery: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 3, should be 0: In scope SELECT showCertificate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT showCertificate(NULL, NULL, NULL);) 2025.04.02 01:50:41.147218 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 3, should be 0: In scope SELECT showCertificate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:41.184265 [ 7799 ] {8e4394c0-be98-4257-a7a5-4ec709d8e438} executeQuery: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 3, should be 1: In scope SELECT sigmoid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT sigmoid(NULL, NULL, NULL);) 2025.04.02 01:50:41.189010 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 3, should be 1: In scope SELECT sigmoid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:41.216493 [ 7799 ] {ac935df5-bc98-439f-83b0-2241ef01215a} executeQuery: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 3, should be 1: In scope SELECT sign(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT sign(NULL, NULL, NULL);) 2025.04.02 01:50:41.223333 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 3, should be 1: In scope SELECT sign(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:41.246281 [ 7799 ] {c562de21-997a-4871-89e8-4a6c9b6ff1ab} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT simpleJSONExtractBool(NULL, NULL, NULL);) 2025.04.02 01:50:41.251491 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:41.275618 [ 7799 ] {7b0399af-8813-454e-b626-2745b0e8424b} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractFloat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT simpleJSONExtractFloat(NULL, NULL, NULL);) 2025.04.02 01:50:41.280470 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractFloat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:41.303003 [ 7799 ] {219fd6b5-9e42-4e38-a442-03cffb5c3708} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT simpleJSONExtractInt(NULL, NULL, NULL);) 2025.04.02 01:50:41.307644 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:41.329218 [ 7799 ] {f5c693a5-6539-46c8-95f6-896e5e137398} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractRaw(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT simpleJSONExtractRaw(NULL, NULL, NULL);) 2025.04.02 01:50:41.334066 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractRaw(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:41.355646 [ 7799 ] {bc59450c-02b3-4f6d-84c4-0b2d008cb715} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT simpleJSONExtractString(NULL, NULL, NULL);) 2025.04.02 01:50:41.360275 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:41.383046 [ 7799 ] {632e64a1-219f-4f8c-a3cf-160017ad8872} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractUInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT simpleJSONExtractUInt(NULL, NULL, NULL);) 2025.04.02 01:50:41.388291 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractUInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:41.408530 [ 7799 ] {88b62f92-bef3-4479-a5d0-a9ba5ff12b13} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT simpleJSONHas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT simpleJSONHas(NULL, NULL, NULL);) 2025.04.02 01:50:41.413357 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT simpleJSONHas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:41.483458 [ 7799 ] {c9831fff-982f-45a3-860a-ab87e65f22b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 3, should be 1: In scope SELECT sin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT sin(NULL, NULL, NULL);) 2025.04.02 01:50:41.488287 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 3, should be 1: In scope SELECT sin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:41.561862 [ 7799 ] {c85d9adb-01a2-49ef-8c26-1dc7864535a7} executeQuery: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 3, should be 1: In scope SELECT sinh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT sinh(NULL, NULL, NULL);) 2025.04.02 01:50:41.566613 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 3, should be 1: In scope SELECT sinh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:41.927245 [ 7799 ] {e50c17f0-1f1c-4ab9-822c-ca5433fbc693} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 3, should be 1: In scope SELECT sleep(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT sleep(NULL, NULL, NULL);) 2025.04.02 01:50:41.931831 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 3, should be 1: In scope SELECT sleep(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:41.952546 [ 7799 ] {b48290be-41c9-49b0-81f4-01d84f1207f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 3, should be 1: In scope SELECT sleepEachRow(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT sleepEachRow(NULL, NULL, NULL);) 2025.04.02 01:50:41.958094 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 3, should be 1: In scope SELECT sleepEachRow(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:42.144997 [ 7799 ] {f6bdccac-84f2-4008-afe2-03b5604e4b91} executeQuery: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 3, should be 1: In scope SELECT soundex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT soundex(NULL, NULL, NULL);) 2025.04.02 01:50:42.149495 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 3, should be 1: In scope SELECT soundex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:42.171481 [ 7799 ] {260a2a26-9534-4001-9974-256e43f60dfa} executeQuery: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 3, should be 1: In scope SELECT space(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT space(NULL, NULL, NULL);) 2025.04.02 01:50:42.176336 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 3, should be 1: In scope SELECT space(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:42.602203 [ 7799 ] {8f2f91c9-dd46-440f-b30d-ccaf387cc044} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 3, should be 1: In scope SELECT sqidDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT sqidDecode(NULL, NULL, NULL);) 2025.04.02 01:50:42.606678 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 3, should be 1: In scope SELECT sqidDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:42.668823 [ 7799 ] {0428c189-3ec8-44c8-85e4-0e6bce13d593} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 3, should be 1: In scope SELECT sqrt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT sqrt(NULL, NULL, NULL);) 2025.04.02 01:50:42.673721 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 3, should be 1: In scope SELECT sqrt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:42.694746 [ 7799 ] {7b2408fd-8fe4-4e30-81cd-afb97d26a4df} executeQuery: Code: 42. DB::Exception: Number of arguments for function startsWith doesn't match: passed 3, should be 2: In scope SELECT startsWith(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT startsWith(NULL, NULL, NULL);) 2025.04.02 01:50:42.699872 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function startsWith doesn't match: passed 3, should be 2: In scope SELECT startsWith(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:42.721040 [ 7799 ] {22f67e59-0ee0-4bd5-afca-eac02a7f32f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function startsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT startsWithUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT startsWithUTF8(NULL, NULL, NULL);) 2025.04.02 01:50:42.726068 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function startsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT startsWithUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:42.948307 [ 7799 ] {167220f4-c004-47ce-a133-fbd5e4aad86a} executeQuery: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT stem(NULL, NULL, NULL);) 2025.04.02 01:50:42.953951 [ 7799 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.04.02 01:50:43.166930 [ 7799 ] {fd9d98a2-8986-471e-90ad-8d77dd32fc84} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT stringJaccardIndex(NULL, NULL, NULL);) 2025.04.02 01:50:43.171692 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:43.194233 [ 7799 ] {b1215d12-9b99-4fc3-93fa-86b314ac29ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndexUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT stringJaccardIndexUTF8(NULL, NULL, NULL);) 2025.04.02 01:50:43.199869 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndexUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:43.225645 [ 7799 ] {3f17dc17-e7e0-42cd-8898-d72bfa15ad3d} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 3, should be 1: In scope SELECT stringToH3(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT stringToH3(NULL, NULL, NULL);) 2025.04.02 01:50:43.231591 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 3, should be 1: In scope SELECT stringToH3(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:43.256687 [ 7799 ] {e269b264-cfc1-433d-9cc9-4a11cacd80bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function structureToCapnProtoSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToCapnProtoSchema(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT structureToCapnProtoSchema(NULL, NULL, NULL);) 2025.04.02 01:50:43.262364 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function structureToCapnProtoSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToCapnProtoSchema(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:43.286874 [ 7799 ] {5a7088fe-f911-4e2b-bbc9-6ff41535d169} executeQuery: Code: 42. DB::Exception: Number of arguments for function structureToProtobufSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToProtobufSchema(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT structureToProtobufSchema(NULL, NULL, NULL);) 2025.04.02 01:50:43.292105 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function structureToProtobufSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToProtobufSchema(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:43.409971 [ 7799 ] {fb4024b1-5ffb-41f5-bd6f-268f74563f38} executeQuery: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 3, should be 2: In scope SELECT subDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT subDate(NULL, NULL, NULL);) 2025.04.02 01:50:43.415043 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 3, should be 2: In scope SELECT subDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:43.437064 [ 3817 ] {2a67d270-6cd6-4e79-8c90-c5546a533501} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:36160) (in query: select _path,_file from file('nonexist.txt', 'CSV', 'val1 char')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ac716ea 4. ./build_docker/./src/Storages/StorageFile.cpp:1624: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003c97bf50 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:939: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000386d105a 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2035: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000386b5db5 7. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000003865cf3b 8. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 12. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 19. ? @ 0x00007f583d9b1ac3 20. ? @ 0x00007f583da43850 2025.04.02 01:50:43.441165 [ 3817 ] {} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ac716ea 4. ./build_docker/./src/Storages/StorageFile.cpp:1624: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003c97bf50 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:939: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000386d105a 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2035: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000386b5db5 7. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000003865cf3b 8. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000003864e1e9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000038646b52 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000392788b1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 12. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 19. ? @ 0x00007f583d9b1ac3 20. ? @ 0x00007f583da43850 2025.04.02 01:50:43.752031 [ 7799 ] {821f0340-0f10-4e21-b41e-fea6f5aa4a07} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractInterval doesn't match: passed 3, should be 2: In scope SELECT subtractInterval(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT subtractInterval(NULL, NULL, NULL);) 2025.04.02 01:50:43.756598 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractInterval doesn't match: passed 3, should be 2: In scope SELECT subtractInterval(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:44.095537 [ 7799 ] {8c43f22e-4ce5-4fed-a64b-4e0a95a6fdd8} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT subtractTupleOfIntervals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT subtractTupleOfIntervals(NULL, NULL, NULL);) 2025.04.02 01:50:44.100619 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT subtractTupleOfIntervals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:44.645947 [ 7799 ] {c7a2bf0c-6e02-4336-845d-1882bb345564} executeQuery: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT synonyms(NULL, NULL, NULL);) 2025.04.02 01:50:44.650190 [ 7799 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.04.02 01:50:44.669793 [ 7799 ] {3c4d0933-bdc7-4c20-838a-4b1fbc1ed962} executeQuery: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 3, should be 1: In scope SELECT tan(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tan(NULL, NULL, NULL);) 2025.04.02 01:50:44.674115 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 3, should be 1: In scope SELECT tan(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:44.693906 [ 7799 ] {0e004667-5b79-4638-9095-8655dcfc7f57} executeQuery: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 3, should be 1: In scope SELECT tanh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tanh(NULL, NULL, NULL);) 2025.04.02 01:50:44.698068 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 3, should be 1: In scope SELECT tanh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:44.717404 [ 7799 ] {778f8923-6f2b-4173-8c9d-5c0f6ba31568} executeQuery: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 3, should be 0: In scope SELECT tcpPort(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tcpPort(NULL, NULL, NULL);) 2025.04.02 01:50:44.721471 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 3, should be 0: In scope SELECT tcpPort(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:44.740782 [ 7799 ] {5ad870cf-3bd5-45ee-8e3d-a9dcdd3e44a1} executeQuery: Code: 42. DB::Exception: Number of arguments for function test_function doesn't match: passed 3, should be 2: In scope SELECT test_function(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT test_function(NULL, NULL, NULL);) 2025.04.02 01:50:44.745215 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function test_function doesn't match: passed 3, should be 2: In scope SELECT test_function(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:44.764259 [ 7799 ] {21af7d9b-7cba-4528-b18d-43083d795781} executeQuery: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 3, should be 1: In scope SELECT tgamma(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tgamma(NULL, NULL, NULL);) 2025.04.02 01:50:44.768585 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 3, should be 1: In scope SELECT tgamma(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:44.874367 [ 7799 ] {dd95f00e-3921-4c28-a179-d5d8de4efedd} executeQuery: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 3, should be 0: In scope SELECT tid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tid(NULL, NULL, NULL);) 2025.04.02 01:50:44.878715 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 3, should be 0: In scope SELECT tid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:44.898001 [ 7799 ] {4aaba675-0377-4bf8-984d-41e592eeaa24} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeDiff doesn't match: passed 3, should be 2: In scope SELECT timeDiff(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT timeDiff(NULL, NULL, NULL);) 2025.04.02 01:50:44.902126 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeDiff doesn't match: passed 3, should be 2: In scope SELECT timeDiff(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:45.005611 [ 7799 ] {b374ebf9-ef01-4cdf-93da-058fecc315d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT timeZone(NULL, NULL, NULL);) 2025.04.02 01:50:45.011865 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:45.035795 [ 7799 ] {3bba9e5d-4951-4df9-a477-545e57a49162} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timeZoneOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT timeZoneOf(NULL, NULL, NULL);) 2025.04.02 01:50:45.040288 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timeZoneOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:45.261309 [ 7799 ] {6024daa4-a1e8-4bcb-9bd1-cbea2c7a3830} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT timezone(NULL, NULL, NULL);) 2025.04.02 01:50:45.267009 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:45.290229 [ 7799 ] {c7e9aae4-3d01-4d10-bf01-527156cfd35f} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timezoneOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT timezoneOf(NULL, NULL, NULL);) 2025.04.02 01:50:45.295444 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timezoneOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:45.481356 [ 7799 ] {a293629f-82eb-4d1b-bde6-e698145e0c5e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 3, should be 1: In scope SELECT toBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toBool(NULL, NULL, NULL);) 2025.04.02 01:50:45.485747 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 3, should be 1: In scope SELECT toBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:45.505870 [ 7799 ] {00f3db26-ae4f-4083-9653-58341c008e7a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 3, should be 1: In scope SELECT toColumnTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toColumnTypeName(NULL, NULL, NULL);) 2025.04.02 01:50:45.510140 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 3, should be 1: In scope SELECT toColumnTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:45.613718 [ 7799 ] {cefa3c98-7d81-4467-9787-eb35ebe9fe42} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDate32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toDate32OrDefault(NULL, NULL, NULL);) 2025.04.02 01:50:45.617966 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDate32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:45.714939 [ 7799 ] {261858d9-dba9-41ca-8c67-84f8209f4442} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDateOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toDateOrDefault(NULL, NULL, NULL);) 2025.04.02 01:50:45.719370 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDateOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:45.930349 [ 7799 ] {2463935a-796d-4c4c-a56b-d9b43347b066} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDateTime64OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toDateTime64OrDefault(NULL, NULL, NULL);) 2025.04.02 01:50:45.935320 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDateTime64OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:46.028086 [ 7799 ] {7f6604ef-c1d1-4adc-acb4-151e433d9f41} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTimeOrDefault'. Expected: const String, got: Nullable(Nothing): In scope SELECT toDateTimeOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toDateTimeOrDefault(NULL, NULL, NULL);) 2025.04.02 01:50:46.032606 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTimeOrDefault'. Expected: const String, got: Nullable(Nothing): In scope SELECT toDateTimeOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:46.328661 [ 7799 ] {b527e00d-6e73-482c-b139-69ad9057b30e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal128OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toDecimal128OrDefault(NULL, NULL, NULL);) 2025.04.02 01:50:46.333052 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal128OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:46.470399 [ 7799 ] {43f4aa36-9a8d-4f13-9782-5b44745cf9a9} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal256OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal256OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toDecimal256OrDefault(NULL, NULL, NULL);) 2025.04.02 01:50:46.474680 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal256OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal256OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:46.608448 [ 7799 ] {2a980f4c-f190-4bef-87a9-54d659d65e0e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal32OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toDecimal32OrDefault(NULL, NULL, NULL);) 2025.04.02 01:50:46.612827 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal32OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:46.749842 [ 7799 ] {d4f4dd5f-2a4f-49d8-8034-d7225b36d946} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal64OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toDecimal64OrDefault(NULL, NULL, NULL);) 2025.04.02 01:50:46.754539 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal64OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:46.859508 [ 7799 ] {385f110f-f940-4f86-a551-910533a85d1e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 3, should be 2: In scope SELECT toDecimalString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toDecimalString(NULL, NULL, NULL);) 2025.04.02 01:50:46.865204 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 3, should be 2: In scope SELECT toDecimalString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:46.888323 [ 7799 ] {f9f9a120-beb0-4b80-8cd0-2f171a40519f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFixedString doesn't match: passed 3, should be 2: In scope SELECT toFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toFixedString(NULL, NULL, NULL);) 2025.04.02 01:50:46.893325 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFixedString doesn't match: passed 3, should be 2: In scope SELECT toFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:46.952025 [ 7799 ] {beb023ef-a3eb-454f-90db-e275f3370226} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toFloat32OrDefault(NULL, NULL, NULL);) 2025.04.02 01:50:46.956402 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:47.089500 [ 7799 ] {5270e370-dba7-4e7f-ab03-4b5773f70c9d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toFloat64OrDefault(NULL, NULL, NULL);) 2025.04.02 01:50:47.094060 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:47.268448 [ 7799 ] {a064e2b6-fdaf-4f6c-8771-8229695c9833} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv4OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toIPv4OrDefault(NULL, NULL, NULL);) 2025.04.02 01:50:47.272914 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv4OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:47.413288 [ 7799 ] {7e13f2b8-c487-46af-a0f0-5916f987ead2} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv6OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toIPv6OrDefault(NULL, NULL, NULL);) 2025.04.02 01:50:47.418391 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv6OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:47.636443 [ 7799 ] {d53bf373-b891-4a12-af36-def36af855f6} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt128OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toInt128OrDefault(NULL, NULL, NULL);) 2025.04.02 01:50:47.642001 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt128OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:47.676940 [ 17965 ] {} BaseDaemon: Integrity check of the executable successfully passed (checksum: 003D0F8422331117266F6835F6AB47FF) 2025.04.02 01:50:47.799227 [ 7799 ] {fa39594b-96b9-4a7d-995e-ee256573b531} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt16OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toInt16OrDefault(NULL, NULL, NULL);) 2025.04.02 01:50:47.804995 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt16OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:47.952652 [ 7799 ] {6df33179-43a0-490b-8b3c-e76cb0a15219} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt256OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toInt256OrDefault(NULL, NULL, NULL);) 2025.04.02 01:50:47.957299 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt256OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:48.105252 [ 7799 ] {9cb001c4-6505-43fd-9abc-ba49d41e298e} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toInt32OrDefault(NULL, NULL, NULL);) 2025.04.02 01:50:48.110403 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:48.245110 [ 7799 ] {4c2195c5-ff83-4b74-af63-4ad81f30ae20} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toInt64OrDefault(NULL, NULL, NULL);) 2025.04.02 01:50:48.251003 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:48.404439 [ 7799 ] {d8ecff4d-1105-4da2-8b44-8f9a9d9587f6} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt8OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toInt8OrDefault(NULL, NULL, NULL);) 2025.04.02 01:50:48.410173 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt8OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:48.986666 [ 7799 ] {290d6960-514a-4b94-9120-7f5d21432588} executeQuery: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 3, should be 1: In scope SELECT toJSONString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toJSONString(NULL, NULL, NULL);) 2025.04.02 01:50:48.991370 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 3, should be 1: In scope SELECT toJSONString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:49.094487 [ 7799 ] {27979ca9-04d6-4190-b627-663daa570c24} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 3, should be 1: In scope SELECT toLowCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toLowCardinality(NULL, NULL, NULL);) 2025.04.02 01:50:49.099201 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 3, should be 1: In scope SELECT toLowCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:49.198250 [ 7799 ] {ff9ec9e1-bb27-45af-b790-7440683dff9f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toModifiedJulianDay(NULL, NULL, NULL);) 2025.04.02 01:50:49.203134 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:49.223228 [ 7799 ] {bc807b77-b5bd-466f-ae1c-f151c1ca854c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDayOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toModifiedJulianDayOrNull(NULL, NULL, NULL);) 2025.04.02 01:50:49.228396 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDayOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:49.328964 [ 7799 ] {21e48efe-a899-4002-8c7c-e8f985ad58b7} executeQuery: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 3, should be 1: In scope SELECT toNullable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toNullable(NULL, NULL, NULL);) 2025.04.02 01:50:49.333781 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 3, should be 1: In scope SELECT toNullable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:50.450263 [ 7799 ] {0fc11259-a264-476f-b975-0fbd97b8e668} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 3, should be 1: In scope SELECT toStringCutToZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toStringCutToZero(NULL, NULL, NULL);) 2025.04.02 01:50:50.454716 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 3, should be 1: In scope SELECT toStringCutToZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:50.515526 [ 7799 ] {05ea2ad3-64b9-4f6e-a74d-24bac5450185} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toTimeZone(NULL, NULL, NULL);) 2025.04.02 01:50:50.519877 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:50.533397 [ 2377 ] {5eed5198-1c3b-442e-a467-206be092b48e} executeQuery: Code: 51. DB::Exception: Empty list of columns in projection. In scope SELECT COLUMNS('x') FROM numbers(10) WHERE number > 5. (EMPTY_LIST_OF_COLUMNS_QUERIED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:36316) (comment: 00969_columns_clause.sql) (in query: SELECT COLUMNS('x') FROM numbers(10) WHERE number > 5;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5565: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d2ba2d 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:50:50.537344 [ 2377 ] {} TCPHandler: Code: 51. DB::Exception: Empty list of columns in projection. In scope SELECT COLUMNS('x') FROM numbers(10) WHERE number > 5. (EMPTY_LIST_OF_COLUMNS_QUERIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5565: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d2ba2d 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 22. ? @ 0x00007f583d9b1ac3 23. ? @ 0x00007f583da43850 2025.04.02 01:50:50.538932 [ 7799 ] {71229fe2-3bbf-4bd2-9cbc-ce1fe687cbd9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toTimezone(NULL, NULL, NULL);) 2025.04.02 01:50:50.543229 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:50.560299 [ 7799 ] {186f5c2f-ba56-4d95-a91c-94a5f3dc78a7} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 3, should be 1: In scope SELECT toTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toTypeName(NULL, NULL, NULL);) 2025.04.02 01:50:50.564519 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 3, should be 1: In scope SELECT toTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:50.626155 [ 7799 ] {58f15d63-a164-4a6f-ad8a-c9fcec55ea36} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt128OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUInt128OrDefault(NULL, NULL, NULL);) 2025.04.02 01:50:50.631489 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt128OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:50.771495 [ 7799 ] {c6d84122-ebc8-4f09-865d-f9877fe9ea5a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt16OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUInt16OrDefault(NULL, NULL, NULL);) 2025.04.02 01:50:50.775945 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt16OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:50.813329 [ 2377 ] {28ef6312-895d-41ba-bff2-6ed42e8b772f} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 0, should be 2: In scope SELECT COLUMNS('n') + COLUMNS('u') FROM (SELECT 1 AS a, 2 AS b). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:36316) (comment: 00969_columns_clause.sql) (in query: SELECT COLUMNS('n') + COLUMNS('u') FROM (SELECT 1 AS a, 2 AS b);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029759d17 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000031bfebe2 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c013f7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 21. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 22. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 28. ? @ 0x00007f583d9b1ac3 29. ? @ 0x00007f583da43850 2025.04.02 01:50:50.817466 [ 2377 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 0, should be 2: In scope SELECT COLUMNS('n') + COLUMNS('u') FROM (SELECT 1 AS a, 2 AS b). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029759d17 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000031bfebe2 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c013f7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 21. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 22. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 28. ? @ 0x00007f583d9b1ac3 29. ? @ 0x00007f583da43850 2025.04.02 01:50:50.903821 [ 7799 ] {41ebda1c-f769-458c-9a9d-a7d33f67a5e3} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt256OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUInt256OrDefault(NULL, NULL, NULL);) 2025.04.02 01:50:50.908257 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt256OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:50.984662 [ 2377 ] {6d5cb9bc-6343-4980-8329-3238448aa6dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 3, should be 2: In scope SELECT COLUMNS('a|b') + COLUMNS('b') FROM (SELECT 1 AS a, 2 AS b). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:36316) (comment: 00969_columns_clause.sql) (in query: SELECT COLUMNS('a|b') + COLUMNS('b') FROM (SELECT 1 AS a, 2 AS b);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029759d17 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000031bfebe2 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c013f7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 21. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 22. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 28. ? @ 0x00007f583d9b1ac3 29. ? @ 0x00007f583da43850 2025.04.02 01:50:50.988157 [ 2377 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 3, should be 2: In scope SELECT COLUMNS('a|b') + COLUMNS('b') FROM (SELECT 1 AS a, 2 AS b). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029759d17 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000031bfebe2 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000031c013f7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035d9f0d2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000035d3c8dc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000035d39a62 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000035dd7cc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000035d24e06 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000035d21906 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000035d1fdd9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000037883c19 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000386434b6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000003863c3ae 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000386476b5 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:279: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000038647233 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000384d96a8 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000039278014 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 21. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 22. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 28. ? @ 0x00007f583d9b1ac3 29. ? @ 0x00007f583da43850 2025.04.02 01:50:51.042183 [ 7799 ] {b730fe17-fe48-407d-a9cb-acc8947123a5} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUInt32OrDefault(NULL, NULL, NULL);) 2025.04.02 01:50:51.047247 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:51.185095 [ 7799 ] {e922822d-40de-4439-8e10-6dc174681fbe} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUInt64OrDefault(NULL, NULL, NULL);) 2025.04.02 01:50:51.190147 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:51.332236 [ 7799 ] {58ab7061-5bf8-44e8-97a5-26ad154d38a7} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt8OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUInt8OrDefault(NULL, NULL, NULL);) 2025.04.02 01:50:51.337396 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt8OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:51.441267 [ 7799 ] {6b9b05f8-2439-4904-8c4f-3fd4b2028c5a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT toUTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUTCTimestamp(NULL, NULL, NULL);) 2025.04.02 01:50:51.445790 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT toUTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:51.501656 [ 7799 ] {83086502-a4dd-4b12-b5d0-76a978449aa9} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUIDOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUUIDOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUUIDOrDefault(NULL, NULL, NULL);) 2025.04.02 01:50:51.506380 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUIDOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUUIDOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:51.641029 [ 7799 ] {eecb022d-9be4-4ca6-a1b8-9b1ff83c6e88} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Micro(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUnixTimestamp64Micro(NULL, NULL, NULL);) 2025.04.02 01:50:51.645524 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Micro(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:51.664000 [ 7799 ] {b87b5cde-119e-4134-8ed4-aa98e157258c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Milli(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUnixTimestamp64Milli(NULL, NULL, NULL);) 2025.04.02 01:50:51.668641 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Milli(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:51.688865 [ 7799 ] {344bc239-7847-4fd3-89f3-91d0e41ee3b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Nano(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUnixTimestamp64Nano(NULL, NULL, NULL);) 2025.04.02 01:50:51.693698 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Nano(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:51.713327 [ 7799 ] {807429b0-5e27-4e13-9223-ef566e79f569} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Second doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Second(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toUnixTimestamp64Second(NULL, NULL, NULL);) 2025.04.02 01:50:51.717950 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Second doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Second(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:51.739984 [ 7799 ] {48e7102d-628e-4fc4-8603-2ceaf1a54687} executeQuery: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT toValidUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT toValidUTF8(NULL, NULL, NULL);) 2025.04.02 01:50:51.744796 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT toValidUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:52.002603 [ 7799 ] {f0d24220-04ae-463a-a24e-004c88e7589a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT to_utc_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT to_utc_timestamp(NULL, NULL, NULL);) 2025.04.02 01:50:52.006950 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT to_utc_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:52.025404 [ 7799 ] {271b628b-3aa6-4264-a9a3-a1497dc9d1fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT today(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT today(NULL, NULL, NULL);) 2025.04.02 01:50:52.030294 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT today(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:52.050592 [ 7799 ] {8ed3a48c-a7d9-41bd-81ef-3c5a7cb09096} executeQuery: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 3, should be 1: In scope SELECT tokens(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tokens(NULL, NULL, NULL);) 2025.04.02 01:50:52.055332 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 3, should be 1: In scope SELECT tokens(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:52.172304 [ 7799 ] {d0381669-9ec2-40e8-ba63-c8abde3cc318} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 3, should be 1: In scope SELECT topLevelDomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT topLevelDomain(NULL, NULL, NULL);) 2025.04.02 01:50:52.177679 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 3, should be 1: In scope SELECT topLevelDomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:52.200323 [ 7799 ] {c78f94ef-3cb1-4bd8-be1f-0a96620a2543} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 3, should be 1: In scope SELECT topLevelDomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT topLevelDomainRFC(NULL, NULL, NULL);) 2025.04.02 01:50:52.205113 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 3, should be 1: In scope SELECT topLevelDomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:52.227538 [ 7799 ] {834a82d4-c399-4f10-8e82-dfe55ebee56e} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 3, should be 0: In scope SELECT transactionID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT transactionID(NULL, NULL, NULL);) 2025.04.02 01:50:52.234459 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 3, should be 0: In scope SELECT transactionID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:52.274596 [ 7799 ] {8a09e91c-617e-4706-9d72-14a3926789b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionLatestSnapshot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT transactionLatestSnapshot(NULL, NULL, NULL);) 2025.04.02 01:50:52.279140 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionLatestSnapshot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:52.298037 [ 7799 ] {da8293f0-12a0-4e46-b0b0-6586f8b785d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionOldestSnapshot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT transactionOldestSnapshot(NULL, NULL, NULL);) 2025.04.02 01:50:52.302592 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionOldestSnapshot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:52.322361 [ 7799 ] {babd046a-9bff-4dee-b268-53dcf2c780df} executeQuery: Code: 43. DB::Exception: Second argument of function transform, must be array of source values to transform from.: In scope SELECT transform(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT transform(NULL, NULL, NULL);) 2025.04.02 01:50:52.326955 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: Second argument of function transform, must be array of source values to transform from.: In scope SELECT transform(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:52.426870 [ 7799 ] {edf30c3a-4b5f-4510-bb17-b7dd4dcdb889} executeQuery: Code: 42. DB::Exception: Number of arguments for function trimBoth doesn't match: passed 3, should be 1: In scope SELECT trimBoth(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT trimBoth(NULL, NULL, NULL);) 2025.04.02 01:50:52.431383 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function trimBoth doesn't match: passed 3, should be 1: In scope SELECT trimBoth(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:52.449742 [ 7799 ] {d28d1c50-aadd-420b-a36f-0ed6062a4896} executeQuery: Code: 42. DB::Exception: Number of arguments for function trimLeft doesn't match: passed 3, should be 1: In scope SELECT trimLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT trimLeft(NULL, NULL, NULL);) 2025.04.02 01:50:52.454185 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function trimLeft doesn't match: passed 3, should be 1: In scope SELECT trimLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:52.475098 [ 7799 ] {9706af1f-8688-4eeb-a01e-65150b7a1a81} executeQuery: Code: 42. DB::Exception: Number of arguments for function trimRight doesn't match: passed 3, should be 1: In scope SELECT trimRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT trimRight(NULL, NULL, NULL);) 2025.04.02 01:50:52.480285 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function trimRight doesn't match: passed 3, should be 1: In scope SELECT trimRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:52.577017 [ 7799 ] {602486e1-c93f-48a5-9b3e-9b0589839370} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase58Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tryBase58Decode(NULL, NULL, NULL);) 2025.04.02 01:50:52.581469 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase58Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:52.600630 [ 7799 ] {c5dcfb77-7811-4f9a-ab28-3168baa70de2} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase64Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tryBase64Decode(NULL, NULL, NULL);) 2025.04.02 01:50:52.605518 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase64Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:52.623488 [ 7799 ] {e5d7ee5a-6a87-47b8-8e9e-b662d87dcf85} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 3, should be 1: In scope SELECT tryBase64URLDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tryBase64URLDecode(NULL, NULL, NULL);) 2025.04.02 01:50:52.628601 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 3, should be 1: In scope SELECT tryBase64URLDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:52.687998 [ 7799 ] {035939c8-4797-45c6-89c4-9c5c285bbcb7} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 3, should be 1: In scope SELECT tryIdnaEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tryIdnaEncode(NULL, NULL, NULL);) 2025.04.02 01:50:52.693112 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 3, should be 1: In scope SELECT tryIdnaEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:52.713836 [ 7799 ] {be22e583-bd97-46b9-a784-33c2d72563bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 3, should be 1: In scope SELECT tryPunycodeDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tryPunycodeDecode(NULL, NULL, NULL);) 2025.04.02 01:50:52.718938 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 3, should be 1: In scope SELECT tryPunycodeDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:52.945799 [ 7799 ] {dc9b905d-2c77-4470-baac-44d4fd4e5038} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleDivide doesn't match: passed 3, should be 2: In scope SELECT tupleDivide(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleDivide(NULL, NULL, NULL);) 2025.04.02 01:50:52.950274 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleDivide doesn't match: passed 3, should be 2: In scope SELECT tupleDivide(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:52.967685 [ 7799 ] {edb54010-0a22-4644-b588-c6d851fc167c} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleDivideByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleDivideByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleDivideByNumber(NULL, NULL, NULL);) 2025.04.02 01:50:52.972831 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleDivideByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleDivideByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:52.991965 [ 7799 ] {e3298a79-0dd5-4302-9198-e84d51edd9a8} executeQuery: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Nullable(Nothing): In scope SELECT tupleElement(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleElement(NULL, NULL, NULL);) 2025.04.02 01:50:52.996823 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Nullable(Nothing): In scope SELECT tupleElement(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:53.018250 [ 7799 ] {9f7108e4-02fa-4b96-ad28-5d50a34d1140} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleHammingDistance doesn't match: passed 3, should be 2: In scope SELECT tupleHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleHammingDistance(NULL, NULL, NULL);) 2025.04.02 01:50:53.023164 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleHammingDistance doesn't match: passed 3, should be 2: In scope SELECT tupleHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:53.042614 [ 7799 ] {48617acb-7a6b-487d-9d66-7a3d8742c9c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDiv doesn't match: passed 3, should be 2: In scope SELECT tupleIntDiv(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleIntDiv(NULL, NULL, NULL);) 2025.04.02 01:50:53.047609 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDiv doesn't match: passed 3, should be 2: In scope SELECT tupleIntDiv(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:53.068635 [ 7799 ] {d06e2b04-03dd-4ac1-9886-c90f85359fd2} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleIntDivByNumber(NULL, NULL, NULL);) 2025.04.02 01:50:53.073754 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:53.093221 [ 7799 ] {a0b2dc54-6e9b-450d-b22d-6f4ee2fa39a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZero doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleIntDivOrZero(NULL, NULL, NULL);) 2025.04.02 01:50:53.098097 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZero doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:53.119708 [ 7799 ] {c27c3443-94ec-4f77-a761-fdd66f37a207} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZeroByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZeroByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleIntDivOrZeroByNumber(NULL, NULL, NULL);) 2025.04.02 01:50:53.124608 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZeroByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZeroByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:53.142641 [ 7799 ] {14556d9f-acaa-42ca-a84e-3f55079f8d3a} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT tupleMinus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleMinus(NULL, NULL, NULL);) 2025.04.02 01:50:53.147894 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT tupleMinus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:53.167759 [ 7799 ] {7f027486-376c-4a8b-a3d0-771e0ec69769} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleModulo doesn't match: passed 3, should be 2: In scope SELECT tupleModulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleModulo(NULL, NULL, NULL);) 2025.04.02 01:50:53.174120 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleModulo doesn't match: passed 3, should be 2: In scope SELECT tupleModulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:53.193006 [ 7799 ] {3d37a4a8-b9ec-4c4a-b0b4-01963db53cea} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleModuloByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleModuloByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleModuloByNumber(NULL, NULL, NULL);) 2025.04.02 01:50:53.197440 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleModuloByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleModuloByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:53.215471 [ 7799 ] {a77ab342-8a10-4c35-a4ac-3b1ce7d1822f} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMultiply doesn't match: passed 3, should be 2: In scope SELECT tupleMultiply(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleMultiply(NULL, NULL, NULL);) 2025.04.02 01:50:53.219796 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMultiply doesn't match: passed 3, should be 2: In scope SELECT tupleMultiply(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:53.238604 [ 7799 ] {bb8d6c7a-3627-434b-8f2d-5038f4d2c6a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMultiplyByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleMultiplyByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleMultiplyByNumber(NULL, NULL, NULL);) 2025.04.02 01:50:53.243004 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMultiplyByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleMultiplyByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:53.260508 [ 7799 ] {60fbed87-aa16-4036-87ea-65de6d3dcec1} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 3, should be 1: In scope SELECT tupleNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleNames(NULL, NULL, NULL);) 2025.04.02 01:50:53.264857 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 3, should be 1: In scope SELECT tupleNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:53.282867 [ 7799 ] {e0a4f8b4-cb97-493f-a07b-d48f109688a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 3, should be 1: In scope SELECT tupleNegate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleNegate(NULL, NULL, NULL);) 2025.04.02 01:50:53.287430 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 3, should be 1: In scope SELECT tupleNegate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:53.305071 [ 7799 ] {0186fa87-6c05-4da5-9376-fa2b8696b779} executeQuery: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT tuplePlus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tuplePlus(NULL, NULL, NULL);) 2025.04.02 01:50:53.309442 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT tuplePlus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:53.329061 [ 7799 ] {cb251588-5b41-4441-b6c0-ecf129bb79c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 3, should be 1: In scope SELECT tupleToNameValuePairs(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT tupleToNameValuePairs(NULL, NULL, NULL);) 2025.04.02 01:50:53.333480 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 3, should be 1: In scope SELECT tupleToNameValuePairs(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:53.351688 [ 7799 ] {d05b73ad-546a-4f9b-90b2-189403929cc4} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT ucase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT ucase(NULL, NULL, NULL);) 2025.04.02 01:50:53.355979 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT ucase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:53.373398 [ 7799 ] {25e6c1d5-cd37-4cd2-aaac-7b58419b350c} executeQuery: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 3, should be 1: In scope SELECT unbin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT unbin(NULL, NULL, NULL);) 2025.04.02 01:50:53.377635 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 3, should be 1: In scope SELECT unbin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:53.395595 [ 7799 ] {29b2b205-6678-4e0c-887e-acec972eca33} executeQuery: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 3, should be 1: In scope SELECT unhex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT unhex(NULL, NULL, NULL);) 2025.04.02 01:50:53.399893 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 3, should be 1: In scope SELECT unhex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:53.678897 [ 7799 ] {120edf8b-b9e7-49f5-9298-36e7793c56b7} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaIntersect doesn't match: passed 3, should be 2: In scope SELECT uniqThetaIntersect(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT uniqThetaIntersect(NULL, NULL, NULL);) 2025.04.02 01:50:53.683296 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaIntersect doesn't match: passed 3, should be 2: In scope SELECT uniqThetaIntersect(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:53.700040 [ 7799 ] {ba7ae750-710c-41a1-b5e7-0753d73e4afa} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaNot doesn't match: passed 3, should be 2: In scope SELECT uniqThetaNot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT uniqThetaNot(NULL, NULL, NULL);) 2025.04.02 01:50:53.704374 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaNot doesn't match: passed 3, should be 2: In scope SELECT uniqThetaNot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:53.721615 [ 7799 ] {c27a6a5f-a635-4ede-8541-ca678645eec8} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaUnion doesn't match: passed 3, should be 2: In scope SELECT uniqThetaUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT uniqThetaUnion(NULL, NULL, NULL);) 2025.04.02 01:50:53.725772 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaUnion doesn't match: passed 3, should be 2: In scope SELECT uniqThetaUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:53.787310 [ 7799 ] {b30c167d-df0e-41c2-8dd0-1201158e7519} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT upper(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT upper(NULL, NULL, NULL);) 2025.04.02 01:50:53.791579 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT upper(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:53.809191 [ 7799 ] {f41b49be-fb58-4863-ac8c-cbdcb083698f} executeQuery: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 3, should be 1: In scope SELECT upperUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT upperUTF8(NULL, NULL, NULL);) 2025.04.02 01:50:53.814281 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 3, should be 1: In scope SELECT upperUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:53.835643 [ 7799 ] {9148d206-08dc-4771-85ae-46cb3373f3b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 3, should be 0: In scope SELECT uptime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT uptime(NULL, NULL, NULL);) 2025.04.02 01:50:53.840366 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 3, should be 0: In scope SELECT uptime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:53.858272 [ 7799 ] {9fd1fb6f-5abd-42f3-b816-2fb7d2d6d80f} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT user(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT user(NULL, NULL, NULL);) 2025.04.02 01:50:53.862622 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT user(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:54.116846 [ 7799 ] {30258deb-5d39-4a4c-a8d6-1038f64ad9ea} executeQuery: Code: 43. DB::Exception: First argument for function variantElement must be Variant or Array of Variant. Actual Nullable(Nothing): In scope SELECT variantElement(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT variantElement(NULL, NULL, NULL);) 2025.04.02 01:50:54.121402 [ 7799 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function variantElement must be Variant or Array of Variant. Actual Nullable(Nothing): In scope SELECT variantElement(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.04.02 01:50:54.138767 [ 7799 ] {227558ef-8550-4d21-9933-e3201af25e51} executeQuery: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 3, should be 1: In scope SELECT variantType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT variantType(NULL, NULL, NULL);) 2025.04.02 01:50:54.143411 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 3, should be 1: In scope SELECT variantType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:54.161401 [ 7799 ] {5a4175b7-9acd-427d-9345-7af3bcbcca2f} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT vectorDifference(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT vectorDifference(NULL, NULL, NULL);) 2025.04.02 01:50:54.165930 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT vectorDifference(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:54.184047 [ 7799 ] {2933b53b-fb1a-4adf-9ed9-ea8bdd3ef414} executeQuery: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT vectorSum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT vectorSum(NULL, NULL, NULL);) 2025.04.02 01:50:54.188829 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT vectorSum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:54.206317 [ 7799 ] {33570936-6f84-4210-8b39-90160ea1cf97} executeQuery: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 3, should be 0: In scope SELECT version(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT version(NULL, NULL, NULL);) 2025.04.02 01:50:54.210794 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 3, should be 0: In scope SELECT version(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:54.228858 [ 7799 ] {e2d976b8-bbd7-44f2-bce1-e1ce5bf8f34b} executeQuery: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 3, should be 1: In scope SELECT visibleWidth(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT visibleWidth(NULL, NULL, NULL);) 2025.04.02 01:50:54.233550 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 3, should be 1: In scope SELECT visibleWidth(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:54.251391 [ 7799 ] {d0f900b1-fbc6-426a-b2b5-3a48bbce5473} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT visitParamExtractBool(NULL, NULL, NULL);) 2025.04.02 01:50:54.255806 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:54.274934 [ 7799 ] {9a08e184-59fd-4f4b-ad29-928acd759fac} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractFloat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT visitParamExtractFloat(NULL, NULL, NULL);) 2025.04.02 01:50:54.279557 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractFloat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:54.296505 [ 7799 ] {63edee55-1ece-4e0e-a084-86b8f12e7beb} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT visitParamExtractInt(NULL, NULL, NULL);) 2025.04.02 01:50:54.301036 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:54.318076 [ 7799 ] {3799e445-1565-4deb-a9d1-fd271c342b24} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractRaw(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT visitParamExtractRaw(NULL, NULL, NULL);) 2025.04.02 01:50:54.323154 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractRaw(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:54.342923 [ 7799 ] {8f9e1e11-b35d-46cc-bd89-a864bfed7c1e} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT visitParamExtractString(NULL, NULL, NULL);) 2025.04.02 01:50:54.348940 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:54.367601 [ 7799 ] {c7c605f4-782e-4cdd-8666-3280d19899f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractUInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT visitParamExtractUInt(NULL, NULL, NULL);) 2025.04.02 01:50:54.372430 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractUInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:54.391878 [ 7799 ] {11d65224-0797-40c8-9ee4-63be992db69a} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT visitParamHas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT visitParamHas(NULL, NULL, NULL);) 2025.04.02 01:50:54.396290 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT visitParamHas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:54.502797 [ 7799 ] {26194818-9c84-46bd-83ce-21ca89f8e5fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT widthBucket(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT widthBucket(NULL, NULL, NULL);) 2025.04.02 01:50:54.507445 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT widthBucket(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:54.525249 [ 7799 ] {a4e298e3-d5f5-44ef-960e-561494745222} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT width_bucket(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT width_bucket(NULL, NULL, NULL);) 2025.04.02 01:50:54.529558 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT width_bucket(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:54.629838 [ 7799 ] {01e53a25-aa98-4935-949d-4d77bcf047c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 3, should be 1: In scope SELECT wkt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT wkt(NULL, NULL, NULL);) 2025.04.02 01:50:54.634398 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 3, should be 1: In scope SELECT wkt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:55.334547 [ 7799 ] {8cbb7a57-4cb2-4c4d-96f7-474aef878c32} executeQuery: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT yandexConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT yandexConsistentHash(NULL, NULL, NULL);) 2025.04.02 01:50:55.338685 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT yandexConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:55.394583 [ 7799 ] {89ac76ea-566a-476f-9d2c-09943fb4769f} executeQuery: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 3, should be 0: In scope SELECT yesterday(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT yesterday(NULL, NULL, NULL);) 2025.04.02 01:50:55.399575 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 3, should be 0: In scope SELECT yesterday(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:55.420939 [ 7799 ] {94d9cf69-3531-43c3-b85a-728f050743d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 3, should be 0: In scope SELECT zookeeperSessionUptime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:50880) (comment: 00534_functions_bad_arguments11.sh) (in query: SELECT zookeeperSessionUptime(NULL, NULL, NULL);) 2025.04.02 01:50:55.426245 [ 7799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 3, should be 0: In scope SELECT zookeeperSessionUptime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.04.02 01:50:57.227592 [ 17965 ] {} BaseDaemon: This ClickHouse version is not official and should be upgraded to the official build. 2025.04.02 01:50:57.229184 [ 17965 ] {} BaseDaemon: Changed settings: min_compress_block_size = 687522, max_compress_block_size = 1478732, max_block_size = 70710, min_external_table_block_size_bytes = 0, max_joined_block_size_rows = 23622, max_insert_threads = 3, max_threads = 2, max_read_buffer_size = 967284, connect_timeout_with_failover_ms = 2000, connect_timeout_with_failover_secure_ms = 3000, idle_connection_timeout = 36000, s3_max_get_rps = 1000000, s3_max_get_burst = 2000000, s3_max_put_rps = 1000000, s3_max_put_burst = 2000000, s3_check_objects_after_upload = true, max_remote_read_network_bandwidth = 1000000000000, max_remote_write_network_bandwidth = 1000000000000, max_local_read_bandwidth = 1000000000000, max_local_write_bandwidth = 1000000000000, stream_like_engine_allow_direct_select = true, enable_multiple_prewhere_read_steps = false, replication_wait_for_inactive_replica_timeout = 30, min_count_to_compile_expression = 0, compile_sort_description = false, group_by_two_level_threshold = 266079, group_by_two_level_threshold_bytes = 46488210, distributed_aggregation_memory_efficient = false, allow_nonconst_timezone_arguments = true, parallel_distributed_insert_select = 1, input_format_parallel_parsing = false, min_chunk_bytes_for_parallel_parsing = 17684731, merge_tree_coarse_index_granularity = 5, min_bytes_to_use_direct_io = 9134778703, min_bytes_to_use_mmap_io = 8004858650, log_queries = true, insert_quorum_timeout = 60000, merge_tree_read_split_ranges_into_intersecting_and_non_intersecting_injection_probability = 0.9399999976158142, http_wait_end_of_query = true, http_response_buffer_size = 1924165, fsync_metadata = false, http_send_timeout = 60., http_receive_timeout = 60., use_index_for_in_with_subqueries_max_values = 1000000000, opentelemetry_start_trace_probability = 0.10000000149011612, max_rows_to_read = 20000000, max_bytes_to_read = 1000000000000, max_bytes_to_read_leaf = 1000000000000, max_rows_to_group_by = 10000000000, max_bytes_before_external_group_by = 0, max_rows_to_sort = 10000000000, max_bytes_to_sort = 10000000000, prefer_external_sort_block_bytes = 1, max_bytes_before_external_sort = 10737418240, max_bytes_before_remerge_sort = 2232045447, max_result_rows = 1000000000, max_result_bytes = 1000000000, max_execution_time = 600., max_execution_time_leaf = 600., max_execution_speed = 100000000000, max_execution_speed_bytes = 10000000000000, timeout_before_checking_execution_speed = 300., max_estimated_execution_time = 600., max_columns_to_read = 20000, max_temporary_columns = 20000, max_temporary_non_const_columns = 20000, max_rows_in_set = 10000000000, max_bytes_in_set = 10000000000, max_rows_in_join = 10000000000, max_bytes_in_join = 10000000000, cross_join_min_rows_to_compress = 0, cross_join_min_bytes_to_compress = 100000000, max_rows_to_transfer = 1000000000, max_bytes_to_transfer = 1000000000, max_rows_in_distinct = 10000000000, max_bytes_in_distinct = 10000000000, max_memory_usage = 5000000000, max_memory_usage_for_user = 32000000000, max_untracked_memory = 1048576, memory_profiler_step = 1048576, max_network_bandwidth = 100000000000, max_network_bytes = 1000000000000, max_network_bandwidth_for_user = 100000000000, max_network_bandwidth_for_all_users = 100000000000, max_temporary_data_on_disk_size_for_user = 100000000000, max_temporary_data_on_disk_size_for_query = 100000000000, max_backup_bandwidth = 100000000000, log_comment = '02221_parallel_replicas_bug.sh', send_logs_level = 'error', prefer_localhost_replica = false, optimize_aggregation_in_order = true, aggregation_in_order_max_block_bytes = 25006055, read_in_order_two_level_merge_threshold = 48, max_hyperscan_regexp_length = 1000000, max_hyperscan_regexp_total_length = 10000000, allow_introspection_functions = true, database_atomic_wait_for_drop_and_detach_synchronously = true, optimize_if_chain_to_multiif = true, optimize_functions_to_subcolumns = false, query_cache_max_size_in_bytes = 10000000, query_cache_max_entries = 100000, distributed_ddl_entry_format_version = 6, external_storage_max_read_rows = 10000000000, external_storage_max_read_bytes = 10000000000, local_filesystem_read_method = 'io_uring', remote_filesystem_read_method = 'read', local_filesystem_read_prefetch = true, remote_filesystem_read_prefetch = false, merge_tree_min_bytes_per_task_for_remote_reading = 8388608, merge_tree_compact_parts_min_granules_to_multibuffer_read = 110, async_insert_busy_timeout_max_ms = 5000, enable_filesystem_cache = true, enable_filesystem_cache_on_write_operations = true, filesystem_cache_segments_batch_size = 1, page_cache_inject_eviction = true, load_marks_asynchronously = true, allow_prefetched_read_pool_for_remote_filesystem = false, allow_prefetched_read_pool_for_local_filesystem = false, filesystem_prefetch_step_marks = 50, filesystem_prefetch_max_memory_usage = 67108864, filesystem_prefetches_limit = 10, max_streams_for_merge_tree_reading = 1000, optimize_sorting_by_input_stream_properties = false, insert_keeper_max_retries = 100, insert_keeper_retry_initial_backoff_ms = 1, insert_keeper_retry_max_backoff_ms = 10, insert_keeper_fault_injection_probability = 0.009999999776482582, allow_experimental_parallel_reading_from_replicas = 0, parallel_replicas_for_non_replicated_merge_tree = true, parallel_replicas_local_plan = false, session_timezone = 'Africa/Khartoum', output_format_native_write_json_as_string = true 2025.04.02 01:50:57.611485 [ 14172 ] {25c07067-d97f-4c93-a438-73db7eb69e08} executeQuery: Code: 202. DB::Exception: Too many simultaneous queries for table test_kna9ybmp.simple (266d3899-c4d6-40bf-806c-c89d86f6564e). Maximum is: 1. (TOO_MANY_SIMULTANEOUS_QUERIES) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:57784) (comment: 01666_merge_tree_max_query_limit.sh) (in query: select * from simple), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x0000000008ef8fed 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8618: DB::MergeTreeData::insertQueryIdOrThrowNoLock(String const&, unsigned long) const @ 0x000000003dfd3798 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8644: DB::MergeTreeData::getQueryIdHolder(String const&, unsigned long) const @ 0x000000003dfd4a9f 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:939: DB::MergeTreeDataSelectExecutor::checkLimits(DB::MergeTreeData const&, DB::ReadFromMergeTree::AnalysisResult const&, std::shared_ptr const&) @ 0x000000003e1dcfdc 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2114: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000408af412 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000004079a755 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000004081866f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000038646949 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:228: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000386462e1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 14. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 15. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 21. ? @ 0x00007f583d9b1ac3 22. ? @ 0x00007f583da43850 2025.04.02 01:50:57.616923 [ 14172 ] {} TCPHandler: Code: 202. DB::Exception: Too many simultaneous queries for table test_kna9ybmp.simple (266d3899-c4d6-40bf-806c-c89d86f6564e). Maximum is: 1. (TOO_MANY_SIMULTANEOUS_QUERIES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x0000000008ef8fed 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8618: DB::MergeTreeData::insertQueryIdOrThrowNoLock(String const&, unsigned long) const @ 0x000000003dfd3798 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8644: DB::MergeTreeData::getQueryIdHolder(String const&, unsigned long) const @ 0x000000003dfd4a9f 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:939: DB::MergeTreeDataSelectExecutor::checkLimits(DB::MergeTreeData const&, DB::ReadFromMergeTree::AnalysisResult const&, std::shared_ptr const&) @ 0x000000003e1dcfdc 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2114: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000408af412 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000004079a755 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000004081866f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000038646949 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:228: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000386462e1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 14. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 15. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 21. ? @ 0x00007f583d9b1ac3 22. ? @ 0x00007f583da43850 2025.04.02 01:50:59.882586 [ 6500 ] {82300279-4c02-415f-b153-8a1076e00308} executeQuery: Code: 48. DB::Exception: CHECK PART/PARTITION are not supported for TinyLog. (NOT_IMPLEMENTED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:57828) (comment: 00063_check_query.sql) (in query: CHECK TABLE check_query_tiny_log PARTITION tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Storages/StorageLog.cpp:918: DB::StorageLog::getCheckTaskList(std::variant, String> const&, std::shared_ptr) @ 0x000000003d415489 5. ./build_docker/./src/Interpreters/InterpreterCheckQuery.cpp:108: DB::InterpreterCheckQuery::execute() @ 0x00000000393d96c7 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:50:59.886430 [ 6500 ] {} TCPHandler: Code: 48. DB::Exception: CHECK PART/PARTITION are not supported for TinyLog. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Storages/StorageLog.cpp:918: DB::StorageLog::getCheckTaskList(std::variant, String> const&, std::shared_ptr) @ 0x000000003d415489 5. ./build_docker/./src/Interpreters/InterpreterCheckQuery.cpp:108: DB::InterpreterCheckQuery::execute() @ 0x00000000393d96c7 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:50:59.898313 [ 6500 ] {a95a2495-3dd5-45ae-9bdf-fc0a3753b664} executeQuery: Code: 48. DB::Exception: CHECK PART/PARTITION are not supported for TinyLog. (NOT_IMPLEMENTED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:57828) (comment: 00063_check_query.sql) (in query: CHECK TABLE check_query_tiny_log PART 'all_0_0_0';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Storages/StorageLog.cpp:918: DB::StorageLog::getCheckTaskList(std::variant, String> const&, std::shared_ptr) @ 0x000000003d415489 5. ./build_docker/./src/Interpreters/InterpreterCheckQuery.cpp:108: DB::InterpreterCheckQuery::execute() @ 0x00000000393d96c7 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:50:59.901370 [ 6500 ] {} TCPHandler: Code: 48. DB::Exception: CHECK PART/PARTITION are not supported for TinyLog. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000088f446a 4. ./build_docker/./src/Storages/StorageLog.cpp:918: DB::StorageLog::getCheckTaskList(std::variant, String> const&, std::shared_ptr) @ 0x000000003d415489 5. ./build_docker/./src/Interpreters/InterpreterCheckQuery.cpp:108: DB::InterpreterCheckQuery::execute() @ 0x00000000393d96c7 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 15. ? @ 0x00007f583d9b1ac3 16. ? @ 0x00007f583da43850 2025.04.02 01:51:00.191868 [ 14209 ] {25abccd0-baf4-4afb-966f-72366115f147} executeQuery: Code: 202. DB::Exception: Too many simultaneous queries for table test_kna9ybmp.simple (266d3899-c4d6-40bf-806c-c89d86f6564e). Maximum is: 1. (TOO_MANY_SIMULTANEOUS_QUERIES) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:39114) (comment: 01666_merge_tree_max_query_limit.sh) (in query: select * from simple where i = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x0000000008ef8fed 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8618: DB::MergeTreeData::insertQueryIdOrThrowNoLock(String const&, unsigned long) const @ 0x000000003dfd3798 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8644: DB::MergeTreeData::getQueryIdHolder(String const&, unsigned long) const @ 0x000000003dfd4a9f 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:939: DB::MergeTreeDataSelectExecutor::checkLimits(DB::MergeTreeData const&, DB::ReadFromMergeTree::AnalysisResult const&, std::shared_ptr const&) @ 0x000000003e1dcfdc 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2114: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000408af412 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000004079a755 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000004081866f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000038646949 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:228: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000386462e1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 14. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 15. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 21. ? @ 0x00007f583d9b1ac3 22. ? @ 0x00007f583da43850 2025.04.02 01:51:00.197055 [ 14209 ] {} TCPHandler: Code: 202. DB::Exception: Too many simultaneous queries for table test_kna9ybmp.simple (266d3899-c4d6-40bf-806c-c89d86f6564e). Maximum is: 1. (TOO_MANY_SIMULTANEOUS_QUERIES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000456d53c9 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000206d2853 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000088cd1d5 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x0000000008ef8fed 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8618: DB::MergeTreeData::insertQueryIdOrThrowNoLock(String const&, unsigned long) const @ 0x000000003dfd3798 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8644: DB::MergeTreeData::getQueryIdHolder(String const&, unsigned long) const @ 0x000000003dfd4a9f 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:939: DB::MergeTreeDataSelectExecutor::checkLimits(DB::MergeTreeData const&, DB::ReadFromMergeTree::AnalysisResult const&, std::shared_ptr const&) @ 0x000000003e1dcfdc 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2114: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000408af412 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000004079a755 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000004081866f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000038646949 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:228: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000386462e1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000003927a6f6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000003926ae84 14. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000003f42c0ff 15. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000003f47f8dc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x00000000459134c0 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000459143f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x00000000457f6395 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000457f2d6e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000457efc91 21. ? @ 0x00007f583d9b1ac3 22. ? @ 0x00007f583da43850 2025.04.02 01:51:01.825359 [ 411 ] {} Application: Child process was terminated by signal 6.